- cache - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- caching - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- callable - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- caller - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- CallerDisconnectedException - Exception in org.apache.hadoop.hbase.ipc
-
Exception indicating that the remote host making this IPC lost its
IPC connection.
- CallerDisconnectedException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallerDisconnectedException
-
- callExecService(Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- 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
- Cell - Interface in org.apache.hadoop.hbase
-
The unit of storage in HBase consisting of the following fields:
- 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
-
- cellScanner() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- cellScanner() - Method in class org.apache.hadoop.hbase.client.Result
-
- CellUtil - Class in org.apache.hadoop.hbase
-
Utility methods helpful slinging
Cell
instances.
- CellUtil() - Constructor for class org.apache.hadoop.hbase.CellUtil
-
- 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
-
- chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically checks if a row/family/qualifier value matches the expected val
If it does, it performs the row mutations.
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Atomically checks if a row/family/qualifier value matches the expected val
If it does, it performs the row mutations.
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- checkForAnd(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'AND'
- checkForOr(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'OR'
- checkForSkip(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'SKIP'
- checkForWhile(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'WHILE'
- checkHBaseAvailable(Configuration) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Check to see if HBase is running.
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
Deprecated.
- 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 target exists.
- checkRegionBoundaries() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- checkScanStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- checkScanStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
-
- 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.
- 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
-
- 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
-
- cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- clearCaches(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Clear any caches that pertain to server name sn
.
- clearHashCache() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Allows flushing the region cache.
- clearRegionCache(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Allows flushing the region cache of all locations that pertain to
tableName
- clearRegionCache(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- clearRegionCache() - Method in class org.apache.hadoop.hbase.client.HTable
-
Explicitly clears the region cache to fetch the latest value from META.
- 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_PORT_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The ZK client port key in the ZK properties map.
- ClientScanner - Class in org.apache.hadoop.hbase.client
-
Implements the scanner interface for the HBase client.
- ClientScanner(Configuration, Scan, TableName) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
Deprecated.
- ClientScanner(Configuration, Scan, byte[]) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
- ClientScanner(Configuration, Scan, TableName, HConnection) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
Create a new ClientScanner for the specified table
Note that the passed
Scan
's start row maybe changed changed.
- ClientScanner(Configuration, Scan, byte[], HConnection) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
- ClientScanner(Configuration, Scan, TableName, HConnection, RpcRetryingCallerFactory) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
- ClientScanner(Configuration, Scan, TableName, HConnection, RpcRetryingCallerFactory, RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
Create a new ClientScanner for the specified table Note that the passed
Scan
's start
row maybe changed changed.
- ClientSmallReversedScanner - Class in org.apache.hadoop.hbase.client
-
Client scanner for small reversed scan.
- ClientSmallReversedScanner(Configuration, Scan, TableName, HConnection) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
-
Create a new ReversibleClientScanner for the specified table Note that the
passed
Scan
's start row maybe changed.
- ClientSmallScanner - Class in org.apache.hadoop.hbase.client
-
Client scanner for small scan.
- ClientSmallScanner(Configuration, Scan, TableName) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallScanner
-
Create a new ClientSmallScanner for the specified table.
- ClientSmallScanner(Configuration, Scan, TableName, HConnection) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallScanner
-
Create a new ClientSmallScanner for the specified table.
- ClientSmallScanner(Configuration, Scan, TableName, HConnection, RpcRetryingCallerFactory, RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallScanner
-
Create a new ShortClientScanner for the specified table Note that the
passed
Scan
's start row maybe changed changed.
- 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
-
- 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[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new table by cloning the snapshot content.
- cloneValue(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- close() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- close() - Method in class org.apache.hadoop.hbase.client.HTable
-
- close() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Releases any resources held or pending changes in internal buffers.
- close() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Closes the scanner and releases any resources it has allocated
- close() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- close() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
- close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
- 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.rest.client.RemoteHTable
-
- closed - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- closeRegion(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Close a region.
- closeRegion(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Close a region.
- closeRegion(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Close a region.
- closeRegionWithEncodedRegionName(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
For expert-admins.
- 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
-
Cluster is fully-distributed
- CLUSTER_IS_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Cluster is standalone or pseudo-distributed
- ClusterStatus - Class in org.apache.hadoop.hbase
-
Status information on the HBase cluster.
- ClusterStatus() - Constructor for class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
Used by Writables and Writables are going away.
- ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, Map<String, RegionState>, String[], Boolean) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
-
- cmp(int) - Method in enum org.apache.hadoop.hbase.util.Order
-
Returns the adjusted trichotomous value according to the ordering imposed by this
Order
.
- 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
-
Deprecated.
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
-
- 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
-
Deprecated.
- 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
-
- com.google.protobuf - package com.google.protobuf
-
- 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(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a table or an individual region.
- compact(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a table or an individual region.
- compact(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a column family within a table or region.
- compact(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a column family within a table or region.
- COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by HBase Shell interface to access this metadata
attribute which denotes if the table is compaction enabled
- 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
-
- CompactionTool - Class in org.apache.hadoop.hbase.regionserver
-
- CompactionTool() - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- comparator - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
-
- comparator - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- 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
-
- CompareFilter - Class in org.apache.hadoop.hbase.filter
-
This is a generic filter to be used to filter by comparison.
- CompareFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
-
Constructor.
- CompareFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
-
Comparison operators.
- compareOp - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareOp - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- compareResults(Result, Result) - Static method in class org.apache.hadoop.hbase.client.Result
-
Does a deep comparison of two Results, down to the byte arrays.
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Get
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Increment
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
Special compareTo method for subclasses, to avoid
copying byte[] unnecessarily.
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- compareTo(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- compareTo(HRegionInfo) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- compareTo(HRegionLocation) - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Compares the descriptor with another descriptor which is passed as a parameter.
- compareTo(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
-
Deprecated.
- compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Compares this split against the given one.
- compareTo(ServerName) - Method in class org.apache.hadoop.hbase.ServerName
-
- compareTo(TableName) - Method in class org.apache.hadoop.hbase.TableName
-
For performance reasons, the ordering is not lexicographic.
- 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.
- compareTo(ByteRange) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
Bitwise comparison of each byte in the array.
- COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- Compression.Algorithm - Enum in org.apache.hadoop.hbase.io.compress
-
Compression algorithms.
- COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- CompressionTest - Class in org.apache.hadoop.hbase.util
-
Compression validation test.
- CompressionTest() - Constructor for class org.apache.hadoop.hbase.util.CompressionTest
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- CONF_SKIP_TMP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- 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
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Deprecated.
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
Deprecated.
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
Deprecated.
- 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, HTable) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
-
Deprecated.
Configure a MapReduce Job to perform an incremental load into the given
table.
- configureIncrementalLoad(Job, HTable) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure a MapReduce Job to perform an incremental load into the given
table.
- connect() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
To repair region consistency, one must call connect() in order to repair
online state.
- connection - Variable in class org.apache.hadoop.hbase.client.HTable
-
- 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 class org.apache.hadoop.hbase.HRegionInfo
-
Returns true if the given inclusive range of rows is fully contained
by this region.
- containsRow(byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Return true if the given row falls in this region.
- Context - Class in org.apache.hadoop.hbase.io.crypto
-
Crypto context.
- convert() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Convert a ClusterStatus to a protobuf ClusterStatus
- convert(ClusterStatusProtos.ClusterStatus) - Static method in class org.apache.hadoop.hbase.ClusterStatus
-
Convert a protobuf ClusterStatus to a ClusterStatus
- convert(HBaseProtos.ColumnFamilySchema) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- convert() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- convert(HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Convert a HRegionInfo to a RegionInfo
- convert(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Convert a RegionInfo to a HRegionInfo
- convert() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- convert(HBaseProtos.TableSchema) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
- 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
- COPROC - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
- CoprocessorException - Exception in org.apache.hadoop.hbase.coprocessor
-
Thrown if a coprocessor encounters any exception.
- CoprocessorException() - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Default Constructor
- CoprocessorException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Constructor with a Class object and exception message.
- CoprocessorException(String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Constructs the exception and supplies a string as the message
- CoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
-
Base class which provides clients with an RPC connection to
call coprocessor endpoint Service
s.
- CoprocessorRpcChannel() - Constructor for class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- coprocessorService() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates and returns a RpcChannel
instance
connected to the active master.
- coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates and returns a RpcChannel
instance connected to the
table region containing the specified row.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates an instance of the given Service
subclass for each table
region spanning the range from the startKey
row to endKey
row (inclusive),
and invokes the passed Batch.Call.call(T)
method with each Service
instance.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates an instance of the given Service
subclass for each table
region spanning the range from the startKey
row to endKey
row (inclusive),
and invokes the passed Batch.Call.call(T)
method with each Service
instance.
- coprocessorService(byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Creates and returns a RpcChannel
instance connected to the
table region containing the specified row.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Creates an instance of the given Service
subclass for each table
region spanning the range from the startKey
row to endKey
row (inclusive),
and invokes the passed Batch.Call.call(T)
method with each Service
instance.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Creates an instance of the given Service
subclass for each table
region spanning the range from the startKey
row to endKey
row (inclusive),
and invokes the passed Batch.Call.call(T)
method with each Service
instance.
- coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- 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
-
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
- copyFamilyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- copyFrom(Result) - Method in class org.apache.hadoop.hbase.client.Result
-
Copy another Result into this one.
- copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy from one buffer to another from given offset
- copyFromStreamToBuffer(ByteBuffer, DataInputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
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.
- copyQualifierTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- copyRowTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
copyTo
- 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(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- copyTagTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the tags info into the tag portion of the cell
- 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
-
- 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
-
- CorruptedSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
Snapshot was corrupt for some reason
- CorruptedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
- 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(List<Cell>) - Static method in class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified List of KeyValues.
- create(List<Cell>, Boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(Cell[]) - Static method in class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified array of KeyValues.
- create() - 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(String) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- create(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- createCell(byte[], byte[], byte[], long, byte, byte[]) - 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
-
- 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
- createClosestRowBefore(byte[]) - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
-
Create the closest row before the specified row
- createComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Parses a comparator of the form comparatorType:comparatorValue form and returns a comparator
- createCompareOp(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Takes a compareOperator symbol as a byte array and returns the corresponding CompareOperator
- createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Create a new HConnection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Create a new HConnection instance using the passed conf
instance.
- createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Create a new HConnection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Create a new HConnection instance using the passed conf
instance.
- createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- 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
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.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
-
Deprecated.
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.
- createHFileCorruptionChecker(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- createHTableInterface(Configuration, byte[]) - Method in class org.apache.hadoop.hbase.client.HTableFactory
-
Deprecated.
- createHTableInterface(Configuration, byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
-
Creates a new HTableInterface.
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
- createMaxByteArray(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create a max byte array with the specified max byte count
- createNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new namespace
- createPlainCompressionStream(OutputStream, Compressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
Creates a compression stream without any additional wrapping into
buffering streams.
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
- 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
-
Builds a TableRecordReader.
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
- createRegionName(TableName, byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
-
Deprecated.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static 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, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
Sets up the actual job.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
Sets up the actual job.
- createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates a new table.
- createTable(HTableDescriptor, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates a new table with the specified number of regions.
- createTable(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates a new table with an initial set of empty regions defined by the
specified split keys.
- createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
Creates a new table.
- createTableAsync(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates a new table but does not block and wait for it to come online.
- createTreeSet() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- createUnescapdArgument(byte[], int, int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Removes the single quote escaping a single quote - thus it returns an unescaped argument
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
- 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_CIPHERPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto algorithm provider, a class name
- 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
- current() - Method in class org.apache.hadoop.hbase.client.Result
-
- currentRegion - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- currentWriteBufferSize - Variable in class org.apache.hadoop.hbase.client.HTable
-
- D - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'D'
- DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- 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.HFileOutputFormat
-
Deprecated.
- 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
- debugLsr(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
ls -r for debugging purposes
- debugLsr(Configuration, Path, HBaseFsck.ErrorReporter) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
ls -r for debugging purposes
- 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
-
- DECODE - Static variable in class org.apache.hadoop.hbase.util.Base64
-
Specify decoding.
- decode(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Very low-level access to decoding ASCII characters in the form of a byte
array.
- decode(String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Decodes data from Base64 notation, automatically detecting gzip-compressed
data and decompressing it.
- decode(String, int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Decodes data from Base64 notation, automatically detecting gzip-compressed
data and decompressing it.
- decode4to3(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Decodes four bytes from array source and writes the resulting
bytes (up to three of them) to destination.
- 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
.
- decodeFileToFile(String, String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Reads infile and decodes it to outfile.
- 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.
- decodeFromFile(String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Convenience method for reading a base64-encoded file and decoding it.
- 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.
- decodeToFile(String, String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Convenience method for decoding data to a file.
- decodeToObject(String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Attempts to decode Base64 data and deserialize a Java Object within.
- 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
- 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.SimplePositionedByteRange
-
- deepCopySubRangeTo(int, int, byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Wrapper for System.arraycopy.
- deepCopySubRangeTo(int, int, byte[], int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- deepCopyTo(byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Wrapper for System.arraycopy.
- deepCopyTo(byte[], int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- deepCopyToNewArray() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Instantiate a new byte[] with exact length, which is at least 24 bytes +
length.
- deepCopyToNewArray() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to use a block cache or not.
- DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default size of blocks in files stored to the filesytem (hfiles).
- DEFAULT_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.HColumnDescriptor
-
Default setting for whether or not to use bloomfilters.
- DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to cache bloom filter blocks on write if block
caching is enabled.
- DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to cache data blocks on write if block caching
is enabled.
- DEFAULT_CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to cache index blocks on write if block
caching is enabled.
- DEFAULT_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.HTableDescriptor
-
Constant that denotes whether the table is compaction enabled by default
- DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default compress tags along with any type of DataBlockEncoding.
- DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default compression type.
- DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default data block encoding algorithm.
- DEFAULT_DISALLOW_WRITES_IN_RECOVERING_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_DISTRIBUTED_LOG_REPLAY_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default value of the flag that enables data block encoding on disk, as
opposed to encoding in cache only.
- DEFAULT_EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to evict cached blocks from the blockcache on
close.
- DEFAULT_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_PREFETCH - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_PREFETCH_LIMIT - 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_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_CONFIG_READ_ZOOKEEPER_CONFIG - 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_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_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_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_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.HColumnDescriptor
-
Default setting for whether to serve from memory or not.
- DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for preventing deleted from being collected immediately.
- DEFAULT_LISTEN_PORT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- DEFAULT_MASTER_HANLDER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- 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_FILE_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default maximum file size
- DEFAULT_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Constant that denotes the maximum default size of the memstore after which
the contents are flushed to the store files
- DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default is not to keep a minimum of versions.
- DEFAULT_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_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- DEFAULT_READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Constant that denotes whether the table is READONLY by default and is false
- DEFAULT_REGION_SERVER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGION_SERVER_META_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_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_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default scope.
- DEFAULT_SLEEP_BEFORE_RERUN - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
- 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_THREAD_WAKE_FREQUENCY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for thread wake frequency
- DEFAULT_TIME_LAG - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
- DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default time to live of cell contents.
- 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
-
Default number of versions of a record to keep.
- DEFAULT_ZK_SESSION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for ZooKeeper session timeout
- 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 client port that the zookeeper listens on
- DEFAULT_ZOOKEPER_MAX_CLIENT_CNXNS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default limit on concurrent client-side zookeeper connections
- DEFAULT_ZOOKEPER_RECOVERABLE_WAITIME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default wait time for the recoverable zookeeper
- DefaultCipherProvider - Class in org.apache.hadoop.hbase.io.crypto
-
The default cipher provider.
- DEFERRED_LOG_FLUSH - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
- Delete - Class in org.apache.hadoop.hbase.client
-
Used to perform Delete operations on a single row.
- Delete(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row.
- Delete(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row and timestamp.
- Delete(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row and timestamp.
- Delete(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row and timestamp.
- Delete(Delete) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
- delete(Delete) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deletes the specified cells/row.
- delete(List<Delete>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deletes the specified cells/rows in bulk.
- delete(Delete) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Deletes the specified cells/row.
- delete(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Deletes the specified cells/rows in bulk.
- delete(String) - 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(Delete) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- delete(List<Delete>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- deleteAllConnections(boolean) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- deleteAllConnections() - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
kept for backward compatibility, but the behavior is broken. HBASE-8983
- deleteCachedRegionLocation(HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deletes cached locations for the specific region.
- deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete the latest version of the specified column.
- deleteColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete the specified version of the specified column.
- deleteColumn(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete a column from a table.
- deleteColumn(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete a column from a table.
- deleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete a column from a table.
- deleteColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of the specified column.
- deleteColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of the specified column with a timestamp less than
or equal to the specified timestamp.
- deleteConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- deleteFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of all columns of the specified family.
- deleteFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all columns of the specified family with a timestamp less than
or equal to the specified timestamp.
- deleteFamilyVersion(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all columns of the specified family with a timestamp equal to
the specified timestamp.
- deleteNamespace(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete an existing namespace.
- deleteSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete an existing snapshot.
- deleteSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete an existing snapshot.
- deleteSnapshots(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete existing snapshots whose names match the pattern passed.
- deleteSnapshots(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete existing snapshots whose names match the pattern passed.
- deleteStaleConnection(HConnection) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- deleteTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deletes a table.
- deleteTable(String) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
Deletes a table.
- deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
Deletes a table.
- deleteTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deletes tables matching the passed in pattern and wait on completion.
- deleteTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete tables matching the passed in pattern and wait on completion.
- 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
-
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.
- disableJSON() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
turns JSON output off, and turns on "pretty strings" for human consumption
- disablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Stop the replication stream to the specified peer.
- disableTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Disable table and wait on completion.
- disableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Starts the disable of a table.
- disableTableAsync(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTableAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Disable tables matching the passed in pattern and wait on completion.
- disableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Disable tables matching the passed in pattern and wait on completion.
- disableValues() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
turns value output off
- DISALLOW_WRITES_IN_RECOVERING - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DISTRIBUTED_LOG_REPLAY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Conf key that enables unflushed WAL edits directly being replayed to region servers
- doBulkLoad(Path, HTable) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
Perform a bulk load of the given directory into the given
pre-existing table.
- doCompare(CompareFilter.CompareOp, ByteArrayComparable, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- doLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the logical value indicating whether on-demand CF loading should be allowed.
- DoNotRetryIOException - Exception in org.apache.hadoop.hbase
-
Subclass if exception is not meant to be retried: e.g.
- DoNotRetryIOException() - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
default constructor
- DoNotRetryIOException(String) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DoNotRetryIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DoNotRetryIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DONT_BREAK_LINES - Static variable in class org.apache.hadoop.hbase.util.Base64
-
Don't break lines when encoding (violates strict Base64 specification)
- doSetup(Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context) - 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.
- doSmokeTest(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
-
- drainInputStreamToBuffer(InputStream) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy from the InputStream to a new heap ByteBuffer until the InputStream is exhausted.
- Driver - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- Driver() - Constructor for class org.apache.hadoop.hbase.mapred.Driver
-
Deprecated.
- Driver - Class in org.apache.hadoop.hbase.mapreduce
-
Driver for hbase mapreduce jobs.
- Driver() - Constructor for class org.apache.hadoop.hbase.mapreduce.Driver
-
- dropDependentColumn - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- dropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- DroppedSnapshotException - Exception in org.apache.hadoop.hbase
-
Thrown during flush if the possibility snapshot content was not properly
persisted into store files.
- DroppedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
-
- DroppedSnapshotException() - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
-
default constructor
- dumpOverlapProblems(Multimap<byte[], HBaseFsck.HbckInfo>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- dumpSidelinedRegions(Map<Path, HBaseFsck.HbckInfo>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- Durability - Enum in org.apache.hadoop.hbase.client
-
Enum describing the durability guarantees for tables and
Mutation
s
Note that the items must be sorted in order of increasing durability
- durability - Variable in class org.apache.hadoop.hbase.client.Mutation
-
- DURABILITY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
- 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 instance.
- 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
- 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 HLog Compression
- ENABLE_WAL_ENCRYPTION - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for enabling HLog encryption, a boolean
- enableCatalogJanitor(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Enable/Disable the catalog janitor
- enableJSON() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
turns JSON output on
- enablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Restart the replication stream to the specified peer.
- enableTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Enable a table.
- enableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- enableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- enableTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Brings a table on-line (enables it).
- enableTableAsync(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- enableTableAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- enableTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Enable tables matching the passed in pattern and wait on completion.
- enableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Enable tables matching the passed in pattern and wait on completion.
- enableValues() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
turns value output on
- 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 - Static variable in class org.apache.hadoop.hbase.util.Base64
-
Specify encoding.
- encode3to4(byte[], byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Encodes up to the first three bytes of array threeBytes and
returns a four-byte array in Base64 notation.
- encode3to4(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Encodes up to three bytes of the array source and writes the
resulting four Base64 bytes to destination.
- ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- 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
.
- encodeBytes(byte[]) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Encodes a byte array into Base64 notation.
- encodeBytes(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Encodes a byte array into Base64 notation.
- encodeBytes(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Encodes a byte array into Base64 notation.
- encodeBytes(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Encodes a byte array into Base64 notation.
- ENCODED_REGION_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.HRegionInfo
-
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(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
.
- encodeFileToFile(String, String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Reads infile and encodes it to outfile.
- 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.
- encodeFromFile(String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Convenience method for reading a binary file and base64-encoding it.
- 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.
- encodeObject(Serializable) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Serializes an object and returns the Base64-encoded version of that
serialized object.
- encodeObject(Serializable, int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Serializes an object and returns the Base64-encoded version of that
serialized object.
- 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.
- encodeToFile(byte[], String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Convenience method for encoding data to a file.
- 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.HColumnDescriptor
-
- Encryption - Class in org.apache.hadoop.hbase.io.crypto
-
A facade for encryption algorithms and related support.
- ENCRYPTION_KEY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- 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
-
Deprecated.
- END_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
- endPersistentOutput() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
ends output of a single, persistent list.
- 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(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
-
- equals(Object) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- equals(Object) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- equals(Object) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- equals(Object) - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- equals(Object) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
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
-
Deprecated.
- equals(Object) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
- equals(Object) - Method in class org.apache.hadoop.hbase.ServerName
-
- equals(Object) - Method in class org.apache.hadoop.hbase.TableName
-
- 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
-
- 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 [].
- estimatedSizeOf(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- exec(ExecutorService, String[]) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- execProcedure(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Execute a distributed procedure on a cluster.
- execute(HConnectable<T>) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
This convenience method invokes the given
HConnectable.connect(org.apache.hadoop.hbase.client.HConnection)
implementation using a
HConnection
instance that lasts just for the
duration of the invocation.
- execute(Cluster, HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Execute a transaction method.
- executePathOnly(Cluster, HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Execute a transaction method given only the path.
- executeURI(HttpMethod, Header[], String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Execute a transaction method given a complete URI.
- executor - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
- exists(Get) - Method in class org.apache.hadoop.hbase.client.HTable
-
Test for the existence of columns in the table, as specified by the Get.
- exists(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Test for the existence of columns in the table, as specified by the Gets.
- exists(Get) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
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.HTableInterface
-
Test for the existence of columns in the table, as specified by the Gets.
- exists(Get) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- exists(List<Get>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
exists(List) is really a list of get() calls.
- 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
-
- 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
-
Deprecated.
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.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 - Class in org.apache.hadoop.hbase.client
-
Used to perform Get operations on a single row.
- Get(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(Get) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Copy-constructor
- get(Get) - Method in class org.apache.hadoop.hbase.client.HTable
-
Extracts certain cells from a given row.
- get(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Extracts certain cells from the given rows, in batch.
- get(Get) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Extracts certain cells from a given row.
- get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Extracts certain cells from the given rows, in batch.
- get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
Returns a list of all KeyValue objects with matching column family and qualifier.
- get() - 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(Get) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- get(List<Get>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- 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 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) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- get() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- get(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- get(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- 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
-
- getACL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getACL() - Method in class org.apache.hadoop.hbase.client.Query
-
- getACLStrategy() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getACLStrategy() - Method in class org.apache.hadoop.hbase.client.Query
-
- getActiveMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Gets the current active master, if available.
- getAdmin(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Establishes a connection to the region server at the specified address.
- getAdmin(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
You can pass master flag but nothing special is done.
- getAliasPassword(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getAllFilters() - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns all known filters
- getAlphabet(int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Returns one of the _SOMETHING_ALPHABET byte arrays depending on the options
specified.
- getAlterStatus(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the status of alter command - indicates how many regions have received
the updated schema Asynchronous operation.
- getAlterStatus(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the status of alter command - indicates how many regions have received
the updated schema Asynchronous operation.
- getAttribute(String) - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Gets an attribute
- getAttribute(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAttributeSize() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAttributesMap() - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Gets all attributes
- getAttributesMap() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAuthorizations() - Method in class org.apache.hadoop.hbase.client.Query
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- 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 class org.apache.hadoop.hbase.ClusterStatus
-
- getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getBlocksize() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- 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
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- 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).
- getBytes() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- 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
-
- 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.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
-
- getClient(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Establishes a connection to the region server at the specified address, and returns
a region client protocol.
- getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getCluster() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
- getClusterId() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getClusterIds() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getClusterStatus() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getClusterStatus() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- getClusterVersion() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- getCode() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
- getColumnCells(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Return the Cells for the specific column.
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getColumnLatest(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
- getColumnLatest(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
- getColumnLatestCell(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
The Cell for the most recent timestamp for a given column.
- getColumnLatestCell(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
The Cell for the most recent timestamp for a given column.
- getColumnOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getCompactionCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompactionCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompactionState(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the current compaction state of a table or region.
- getCompactionState(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the current compaction state of a table or region.
- getComparator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- getComparator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getComparator() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
-
This does not really belong inside RegionLoad but its being done in the name of expediency.
- getCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- 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 class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.HTable
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Getter for accessing the configuration value by key.
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Getter for accessing the configuration value by key
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
Getter for accessing the configuration value by key
- getConnection() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getConnection() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- getConnection() - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
This method will be changed from public to package protected.
- getCoprocessors() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Return the list of attached co-processor represented by their name className
- 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.
- getCurrentNrHRS() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
This method will be changed from public to package protected.
- 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.
- 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 class org.apache.hadoop.hbase.HColumnDescriptor
-
- getDataBlockEncodingOnDisk() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- getDate() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
The date that hbase was compiled.
- getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Returns the daughter regions by reading the corresponding columns of the catalog table
Result.
- getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getDeadServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getDecodabet(int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Returns one of the _SOMETHING_DECODABET byte arrays depending on the
options specified.
- getDecompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return a decryptor for decrypting data.
- getDefaultExecutor(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- getDefaultValues() - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getDesc(List<Throwable>, List<? extends Row>, List<String>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getDesc(Map<String, Integer>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getDropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getDurability() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Get the current durability
- getDurability() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the durability setting for the table.
- getEncodedName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getEncodedNameAsBytes() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- 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 class org.apache.hadoop.hbase.HColumnDescriptor
-
Return the raw crypto key attribute for the family, or null if not set
- getEncryptionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Return the encryption algorithm in use by this family
- 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 class org.apache.hadoop.hbase.HRegionInfo
-
- getEndKeys() - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets the ending row key for every region in the currently open table.
- getEndRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
- getEndRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the end row.
- getErrors() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- 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).
- getFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns an unmodifiable collection of all the
HColumnDescriptor
of all the column families of the table.
- getFamiliesKeys() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns all the column family names of the current table.
- getFamily() - Method in interface org.apache.hadoop.hbase.Cell
-
- getFamily() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getFamily() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the HColumnDescriptor for a specific column family with name as
specified by the parameter column.
- 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() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getFamilyMap(byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Map of qualifiers to values.
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Scan
-
Getting the familyMap
- getFamilyMapOfLongs() - Method in class org.apache.hadoop.hbase.client.Increment
-
Before 0.95, when you called Increment#getFamilyMap(), you got back
a map of families to a list of Longs.
- 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
- 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.
- getHashType(Configuration) - Static method in class org.apache.hadoop.hbase.util.Hash
-
This utility method converts the name of the configured
hash type to a symbolic constant.
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getHFilecorruptionChecker() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- 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.ServerName
-
- getHostnamePort(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getHostnamePort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Returns HRegionInfo object from the column
HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog
table Result.
- getHRegionInfo(Result, byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getHRegionInfoAndServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Extract a HRegionInfo and ServerName from catalog table
Result
.
- getHTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Deprecated.
Allows subclasses to get the
HTable
.
- getHTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to get the
HTable
.
- getHTableDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getHTableDescriptor(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getHTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getHTableDescriptorsByTableName(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getHTableMultiplexerStatus() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- 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
-
- getInfoServerPort() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getInstance() - Static method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getInstance(int) - Static method in class org.apache.hadoop.hbase.util.Hash
-
Get a singleton instance of hash function of a given type.
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.util.Hash
-
Get a singleton instance of hash function of a type
defined in the configuration.
- getInstance() - Static method in class org.apache.hadoop.hbase.util.JenkinsHash
-
- getInstance() - Static method in class org.apache.hadoop.hbase.util.MurmurHash
-
- getInt(Configuration, String, String, int) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Get the value of the name
property as an int
, possibly
referring to the deprecated name of the configuration property.
- 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
- getKeepAliveMasterService() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- 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
-
- 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
-
Deprecated.
- 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.SimpleByteRange
-
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getLiveMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getLiveRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getLoad(ServerName) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Originally, this method factored in the effect of requests going to the
server as well.
- getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
- getLocation() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region's location as an array.
- getMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to all versions of its qualifiers and values.
- getMaster() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Returns a MasterKeepAliveConnection
to the active master
- getMaster() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Returns detailed information about the current master
ServerName
.
- getMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- 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
-
- getMaxColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMaxFileSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the maximum size upto which a region can grow to after which a region
split is triggered.
- getMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getMaxKeyValueSize(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- getMaxMerge() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getMaxOverlapsToSideline() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- 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 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
-
- 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 class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the size of the memstore after which a flush to filesystem is triggered.
- getMemstoreSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getMergeRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Returns the merge regions by reading the corresponding columns of the catalog table
Result.
- 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 class org.apache.hadoop.hbase.HColumnDescriptor
-
- getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- getMvccVersion() - Method in interface org.apache.hadoop.hbase.Cell
-
Internal use only.
- getName() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getName() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Gets the fully qualified table name instance of this table.
- getName() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Get the name of the table as a byte array.
- getName() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- 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.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.rest.client.RemoteHTable
-
- getName() - Method in class org.apache.hadoop.hbase.TableName
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Get the name of the table as a String
- getNameAsString() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- 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.TableName
-
- getNamespaceAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get a namespace descriptor by name
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
-
If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is
the next key it must seek to.
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Deprecated.
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Deprecated.
- getNonceGenerator() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- 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
-
- 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.SimpleByteRange
-
- getOnlineRegions(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get all the online regions on a region server.
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
-
- 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
-
- 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.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.
- getOverlapGroups(TableName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getOwnerString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- getPartition(ImmutableBytesWritable, V2, int) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
Deprecated.
- 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.
- getPeersCount() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Get the number of slave clusters the local cluster has.
- getPeerState(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Get the state of the specified peer cluster
- getPeerTableCFs(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Get the replicable table-cf config of the specified peer.
- getPort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getPort() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- getPort() - Method in class org.apache.hadoop.hbase.ServerName
-
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
- getPosition() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
The current position
marker.
- getPosition() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- 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
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
- 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.
- getProvider() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the provider for this Cipher
- getQualifier() - Method in interface org.apache.hadoop.hbase.Cell
-
- 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
-
- getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a random symmetric key
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Deprecated.
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
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
-
Deprecated.
- 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.
- getRegionCachePrefetch(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Check whether region cache prefetch is enabled or not.
- getRegionCachePrefetch(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getRegionCachePrefetch(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Check whether region cache prefetch is enabled or not for the table.
- getRegionCachePrefetch(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- getRegionCachePrefetch(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Check whether region cache prefetch is enabled or not for the table.
- getRegionCachePrefetch(TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- getRegionId() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getRegionLocation(TableName, byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Find region location hosting passed row
- getRegionLocation(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getRegionLocation(String) - Method in class org.apache.hadoop.hbase.client.HTable
-
Find region location hosting passed row using cached info
- getRegionLocation(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Finds the region on which the given row is being served.
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region location.
- getRegionLocations() - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets all the regions and their address for this table.
- getRegionName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Return the RegionServer-level coprocessors
- getRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getRegionsInRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Get the corresponding regions for an arbitrary range of keys.
- getRegionsInRange(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Get the corresponding regions for an arbitrary range of keys.
- getRegionsInTransition() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRegionsLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRegionSplitPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
This get the class associated with the region split policy which
determines when a region split should occur.
- getRemaining() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
The number of bytes remaining between position and the end of the range.
- getRemaining() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- 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
-
- getRestVersion() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- getRetCode() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- 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 interface org.apache.hadoop.hbase.Cell
-
- 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
-
misc
- getRowComparator() - Method in class org.apache.hadoop.hbase.TableName
-
Get the appropriate row comparator for this table.
- 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)
- getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Return the row that matches row exactly,
or the one that immediately precedes it.
- getRowOrBefore(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Deprecated.
As of version 0.92 this method is deprecated without
replacement.
getRowOrBefore is used internally to find entries in hbase:meta and makes
various assumptions about the table (which are true for hbase:meta but not
in general) to be efficient.
- getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getRsCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Return the RegionServer-level and Region-level coprocessors
- getScan() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Gets the scan defining the actual details like columns etc.
- getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns a Scan object from the stored string representation.
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.client.HTable
-
Returns a scanner on the current table as specified by the
Scan
object.
- getScanner(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets a scanner on the current table for the given family.
- getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets a scanner on the current table for the given family and qualifier.
- getScanner(Scan) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Returns a scanner on the current table as specified by the
Scan
object.
- getScanner(byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Gets a scanner on the current table for the given family.
- getScanner(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Gets a scanner on the current table for the given family and qualifier.
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getScanner(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getScannerCaching() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getScannerCallable(byte[], int) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getScannerCallable(byte[], int, byte[]) - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
-
- getScans() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to get the list of
Scan
objects.
- getScope() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getSecond() - Method in class org.apache.hadoop.hbase.util.Pair
-
Return the second element stored in the pair.
- getSecond() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
Return the second element stored in the pair.
- getSecretKeyForSubject(String, Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Resolves a key for the given subject
- getSeqNum() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getSeqNumDuringOpen(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
The latest seqnum that the server writing to meta observed when opening the region.
- getServerInfo() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getServerName() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getServerName() - Method in class org.apache.hadoop.hbase.ServerName
-
- getServerName(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getServerNameLessStartCode(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
Utility method to excise the start code from a server name
- getServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServerStartcodeFromServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getShortNameToLog() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getSize() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- getSnapshotDescription() - Method in exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
- getSnapshotList(Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the list of available snapshots in the specified location
- getSnapshotStats(Configuration, HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the snapshot stats
- getSource() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
- getSourceName() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Deprecated.
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
- getStart() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getStartcode() - Method in class org.apache.hadoop.hbase.ServerName
-
- getStartEndKeys() - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets the starting and ending row keys for every region in the currently
open table.
- getStartKey(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Gets the start key from the specified region name.
- getStartKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getStartKeys() - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets the starting row key for every region in the currently open table.
- getStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getStartRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
- getStartRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the start row.
- getStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- getStorefileIndexSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStorefileSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStores() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStores() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStream() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Gets the input stream instance.
- getSupportedCiphers() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Return the set of Ciphers supported by this provider
- getSupportedCiphers() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getSupportedCiphers() - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get names of supported encryption algorithms
- getSupportedCiphers(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get names of supported encryption algorithms
- getSupportedFilters() - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Return a Set of filters supported by the Filter Language
- getTable() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getTable(String) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Retrieve an HTableInterface implementation for access to a table.
- getTable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Retrieve an HTableInterface implementation for access to a table.
- getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Retrieve an HTableInterface implementation for access to a table.
- getTable(String, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Retrieve an HTableInterface implementation for access to a table.
- getTable(byte[], ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Retrieve an HTableInterface implementation for access to a table.
- getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Retrieve an HTableInterface implementation for access to a table.
- getTable(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Gets the table name from the specified region name.
- getTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Get current table name of the region
- getTable() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
- getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the table name.
- getTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Method for getting the tableDescriptor
- getTableDescriptor(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getTableDescriptor() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getTableDescriptors(List<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get tableDescriptors
- getTableDescriptorsByTableName(List<TableName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get tableDescriptors
- getTableDir(Path, byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getTableList() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets the name of this table.
- getTableName() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Gets the name of this table.
- getTableName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Since 0.96.0; use #getTable(byte[])
- getTableName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Since 0.96.0; use #getTable()
- getTableName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Get the name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
- getTableName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the table name converted to a byte array.
- getTableName() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getTableNames() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deprecated.
- getTableNames(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deprecated.
- getTableNames(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deprecated.
- getTableNames() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getTableRegions(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
get the regions of a given table.
- getTableRegions(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTagArray(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns tag value in a new byte array.
- getTagsArray() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTagsLength() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTagsLengthUnsigned() - Method in interface org.apache.hadoop.hbase.Cell
-
Deprecated.
From next major version this will be renamed to getTagsLength() which returns int.
- getTagsOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's TimeRange
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Increment
-
Gets the TimeRange used for this increment.
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getTimestamp() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getTimeStamp() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the timestamp
- getTimestamps() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- getTimeToLive() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getTypeByte() - Method in interface org.apache.hadoop.hbase.Cell
-
- getUnit(String) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getUrl() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the subversion URL for the root hbase directory.
- getUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getUser() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
The user that compiled hbase.
- getUtf8ByteArrays(List<String>) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- getValue() - Method in interface org.apache.hadoop.hbase.Cell
-
- getValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Get the latest version of the specified column.
- getValue() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- getValue() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- getValue(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getValue(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Getter for accessing the metadata associated with the key
- getValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Getter for accessing the metadata associated with the key
- getValueArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getValueAsByteBuffer(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value wrapped in a new ByteBuffer
.
- getValueAsByteBuffer(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value wrapped in a new ByteBuffer
.
- getValueBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getValueLength() - Method in interface org.apache.hadoop.hbase.Cell
-
- getValueOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
- getValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getVersion() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
HRI is no longer a VersionedWritable
- getVersion() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the hbase version.
- getVersionedBytes() - Method in class org.apache.hadoop.hbase.ServerName
-
- getWriteBuffer() - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
since 0.96. This is an internal buffer that should not be read nor write.
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.HTable
-
Returns the maximum size in bytes of the write buffer for this HTable.
- getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Returns the maximum size in bytes of the write buffer for this HTable.
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getWriteToWAL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- GREATER_THAN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
GREATER_THAN Array
- GREATER_THAN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- GREATER_THAN_OR_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
GREATER_THAN_OR_EQUAL_TO Array
- GREATER_THAN_OR_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Deprecated.
JobConf parameter to specify the columns used to produce the key passed to
collect from the map phase
- GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
JobConf parameter to specify the columns used to produce the key passed to
collect from the map phase.
- GroupingTableMap - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- GroupingTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Deprecated.
- GroupingTableMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Extract grouping columns from input record.
- GroupingTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
- groupOrSplit(Multimap<ByteBuffer, LoadIncrementalHFiles.LoadQueueItem>, LoadIncrementalHFiles.LoadQueueItem, HTable, Pair<byte[][], byte[][]>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
Attempt to assign the given load queue item into its target region group.
- GZIP - Static variable in class org.apache.hadoop.hbase.util.Base64
-
Specify that data should be gzip-compressed.
- H - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'H'
- has(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
A convenience method to determine if this object's familyMap contains
a value assigned to the given family & qualifier.
- has(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Put
-
A convenience method to determine if this object's familyMap contains
a value assigned to the given family, qualifier and timestamp.
- has(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
A convenience method to determine if this object's familyMap contains
a value assigned to the given family, qualifier and timestamp.
- has(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
A convenience method to determine if this object's familyMap contains
the given value assigned to the given family, qualifier and timestamp.
- hasBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- hasCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the table has an attached co-processor represented by the name className
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for checking if any families have been inserted into this Get
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.Increment
-
Method for checking if any families have been inserted into this Increment
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
- hasFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Checks to see if this table contains the given column family
- hasFilter() - Method in class org.apache.hadoop.hbase.client.Scan
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
-
Primarily used to check for conflicts with scans(such as scans that do not read a full row at a
time).
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- hasFoundKV() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- Hash - Class in org.apache.hadoop.hbase.util
-
This class represents a common API for hashing functions.
- Hash() - Constructor for class org.apache.hadoop.hbase.util.Hash
-
- hash(byte[]) - Method in class org.apache.hadoop.hbase.util.Hash
-
Calculate a hash using all bytes from the input argument, and
a seed of -1.
- hash(byte[], int) - Method in class org.apache.hadoop.hbase.util.Hash
-
Calculate a hash using all bytes from the input argument,
and a provided seed value.
- hash(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Hash
-
Calculate a hash using bytes from 0 to length
, and
the provided seed value
- hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.Hash
-
Calculate a hash using bytes from offset
to offset +
length
, and the provided seed value.
- hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.JenkinsHash
-
taken from hashlittle() -- hash a variable-length key into a 32-bit value
- hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.MurmurHash
-
- hash128(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the MD5 digest of the concatenation of the supplied arguments.
- hash128(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the MD5 digest of the concatenation of the supplied arguments.
- hash256(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the SHA-256 digest of the concatenation of the supplied arguments.
- hash256(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the SHA-256 digest of the concatenation of the supplied arguments.
- hashCode() - Method in class org.apache.hadoop.hbase.client.Get
-
- hashCode() - Method in class org.apache.hadoop.hbase.client.Increment
-
- hashCode() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- hashCode() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- hashCode() - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- hashCode() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- hashCode() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- hashCode() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
- hashCode() - Method in class org.apache.hadoop.hbase.ServerName
-
- hashCode() - Method in class org.apache.hadoop.hbase.TableName
-
- hashCode(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- hashCode(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- hashCode(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- hashCode() - Method in class org.apache.hadoop.hbase.util.Pair
-
- hashCode() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
- hashCode() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- hasHigherPriority(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns which operator has higher precedence
- hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- hasNext() - Method in class org.apache.hadoop.hbase.types.StructIterator
-
- hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- HBASE_CHECKSUM_VERIFICATION - Static variable in class org.apache.hadoop.hbase.HConstants
-
If this parameter is set to true, then hbase will read
data and then verify checksums.
- HBASE_CLIENT_CONNECTION_IMPL - Static variable in interface org.apache.hadoop.hbase.client.HConnection
-
Key for configuration in Configuration whose value is the class we implement making a
new HConnection instance.
- HBASE_CLIENT_INSTANCE_ID - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for unique identifier for this Configuration
instance.
- HBASE_CLIENT_IPC_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client IPC pool size
- HBASE_CLIENT_IPC_POOL_TYPE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client IPC pool type
- HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of concurrent connections the client will maintain to a single
Region.
- HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of concurrent connections the client will maintain to a single
RegionServer.
- HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of concurrent connections the client will maintain.
- HBASE_CLIENT_META_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client operation timeout, which overrides RPC timeout
- HBASE_CLIENT_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client operation timeout, which overrides RPC timeout
- HBASE_CLIENT_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for client pause value, used mostly as value to wait
before running a retry of a failed get, region lookup, etc.
- HBASE_CLIENT_PREFETCH - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for client region location prefetch toggle.
- HBASE_CLIENT_PREFETCH_LIMIT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for client prefetch limit, used as the maximum number of regions
info that will be prefetched.
- HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for maximum retries, used as maximum for all retryable
operations such as fetching of the root region from root region server,
getting a cell's value, starting a row update, etc.
- HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name to set the default scanner caching for all clients.
- HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for maximum number of bytes returned when calling a
scanner's next method.
- HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
The client scanner timeout period in milliseconds.
- HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_CONFIG_READ_ZOOKEEPER_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase instance root directory
- HBASE_MASTER_LOADBALANCER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config for pluggable load balancers
- HBASE_MASTER_LOGCLEANER_PLUGINS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for number of rows that will be fetched when calling next on
a scanner if it is not served from memory.
- HBASE_NON_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Directories that are not HBase table directories
- HBASE_NON_USER_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Directories that are not HBase user table directories
- HBASE_REGION_SPLIT_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_REGIONSERVER_LEASE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.
This config option is deprecated. Will be removed at later releases after 0.96.
- HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
timeout for short operation RPC
- HBASE_RPC_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
timeout for each RPC
- HBASE_RS_NONCES_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Whether nonces are enabled; default is true.
- HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for server pause value, used mostly as value to wait before
running a retry of a failed operation.
- HBASE_TEMP_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Temporary directory used for table creation and deletion
- HBaseAdmin - Class in org.apache.hadoop.hbase.client
-
Provides an interface to manage HBase database table metadata + general
administrative functions.
- HBaseAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
-
Constructor.
- HBaseAdmin(HConnection) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
-
Constructor for externally managed HConnections.
- HBASECLIENT_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for what hbase client implementation to use.
- HBaseConfiguration - Class in org.apache.hadoop.hbase
-
Adds HBase configuration files to a Configuration
- HBaseConfiguration() - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
-
Deprecated.
- HBaseConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
-
Deprecated.
- HBaseFsck - Class in org.apache.hadoop.hbase.util
-
HBaseFsck (hbck) is a tool for checking and repairing region consistency and
table integrity problems in a corrupted HBase.
- HBaseFsck(Configuration) - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck
-
Constructor
- HBaseFsck(Configuration, ExecutorService) - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck
-
Constructor
- HBaseInterfaceAudience - Class in org.apache.hadoop.hbase
-
This class defines constants for different classes of hbase limited private apis
- HBaseInterfaceAudience() - Constructor for class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
- HBaseIOException - Exception in org.apache.hadoop.hbase
-
All hbase specific IOExceptions should be subclasses of HBaseIOException
- HBaseIOException() - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
-
- HBaseIOException(String) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
-
- HBaseIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
-
- HBaseIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
-
- HBaseSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
General exception base class for when a snapshot fails
- HBaseSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Some exception happened for a snapshot and don't even know the snapshot that it was about
- HBaseSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Exception for the given snapshot that has no previous root cause
- HBaseSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Exception for the given snapshot due to another exception
- HBaseSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Exception when the description of the snapshot cannot be determined, due to some root other
root cause
- HBCK_CODE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
HBCK special code name used as server name when manipulating ZK nodes
- HBCK_SIDELINEDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used by HBCK to sideline backup data
- HColumnDescriptor - Class in org.apache.hadoop.hbase
-
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
- HColumnDescriptor() - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
Used by Writables and Writables are going away.
- HColumnDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
Construct a column descriptor specifying only the family name
The other attributes are defaulted.
- HColumnDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
Construct a column descriptor specifying only the family name
The other attributes are defaulted.
- HColumnDescriptor(HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
Constructor.
- HColumnDescriptor(byte[], int, String, boolean, boolean, int, String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
- HColumnDescriptor(byte[], int, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
- HColumnDescriptor(byte[], int, int, boolean, String, boolean, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
- HConnection - Interface in org.apache.hadoop.hbase.client
-
A cluster connection.
- HConnectionManager - Class in org.apache.hadoop.hbase.client
-
A non-instantiable class that manages creation of
HConnection
s.
- HConstants - Class in org.apache.hadoop.hbase
-
HConstants holds a bunch of HBase-related constants
- head(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a HEAD request
- head(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a HEAD request
- head(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- HEALTH_CHORE_WAKE_FREQ - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of health check failures a server can encounter consecutively.
- HEALTH_SCRIPT_LOC - Static variable in class org.apache.hadoop.hbase.HConstants
-
Health script related settings.
- HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- heapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- HFILE_ARCHIVE_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Directory under /hbase where archived hfiles are stored
- HFILE_BLOCK_CACHE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HFILE_BLOCK_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the size of the block cache
- HFILEBLOCK_DUMMY_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Just an array of bytes of the right size.
- HFILEBLOCK_HEADER_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
The size of a version 2 HFile block header, minor version 1.
- HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM - Static variable in class org.apache.hadoop.hbase.HConstants
-
The size data structures with minor version is 0
- HFileOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
- HFileOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
-
Deprecated.
- HFileOutputFormat2 - Class in org.apache.hadoop.hbase.mapreduce
-
Writes HFiles.
- HFileOutputFormat2() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- HFilePrettyPrinter - Class in org.apache.hadoop.hbase.io.hfile
-
Implements pretty-printing functionality for HFile
s.
- HFilePrettyPrinter() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- HFilePrettyPrinter(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- HIGH_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- hint - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- HINT_LOOKAHEAD - Static variable in class org.apache.hadoop.hbase.client.Scan
-
EXPERT ONLY.
- HLogInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Simple InputFormat
for HLog
files.
- HLogInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
- HLogPrettyPrinter - Class in org.apache.hadoop.hbase.regionserver.wal
-
HLogPrettyPrinter prints the contents of a given HLog with a variety of
options affecting formatting and extent of content.
- HLogPrettyPrinter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
Basic constructor that simply initializes values to reasonable defaults.
- HLogPrettyPrinter(boolean, boolean, long, String, String, boolean, PrintStream) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
Fully specified constructor.
- HOUR_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HQuorumPeer - Class in org.apache.hadoop.hbase.zookeeper
-
HBase's version of ZooKeeper's QuorumPeer.
- HQuorumPeer() - Constructor for class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
-
- HREGION_COMPACTIONDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used to construct the name of the compaction directory during compaction
- HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HREGION_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used to construct the name of the log directory for a region server
- HREGION_MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Conf key for the max file size after which we split the region
- HREGION_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Conf key for the memstore size at which we flush the memstore
- HREGION_OLDLOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Like the previous, but for old logs that are about to be deleted
- HRegionInfo - Class in org.apache.hadoop.hbase
-
HRegion information.
- HRegionInfo() - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Used by Writables and Writables are going away.
- HRegionInfo(TableName) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
- HRegionInfo(TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Construct HRegionInfo with explicit parameters
- HRegionInfo(TableName, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Construct HRegionInfo with explicit parameters
- HRegionInfo(TableName, byte[], byte[], boolean, long) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Construct HRegionInfo with explicit parameters
- HRegionInfo(HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Costruct a copy of another HRegionInfo
- HRegionLocation - Class in org.apache.hadoop.hbase
-
Data structure to hold HRegionInfo and the address for the hosting
HRegionServer.
- HRegionLocation(HRegionInfo, ServerName) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
-
- HRegionLocation(HRegionInfo, ServerName, long) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
-
- HRegionPartitioner<K2,V2> - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
Deprecated.
- HRegionPartitioner<KEY,VALUE> - Class in org.apache.hadoop.hbase.mapreduce
-
This is used to partition the output keys into groups of keys.
- HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
- HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
The max number of threads used for opening and closing stores or store
files in parallel
- HTable - Class in org.apache.hadoop.hbase.client
-
Used to communicate with a single HBase table.
- HTable(Configuration, String) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(Configuration, byte[]) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(Configuration, TableName) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(TableName, HConnection) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(Configuration, byte[], ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(Configuration, TableName, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(byte[], HConnection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(TableName, HConnection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable() - Constructor for class org.apache.hadoop.hbase.client.HTable
-
For internal testing.
- HTableDescriptor - Class in org.apache.hadoop.hbase
-
HTableDescriptor contains the details about an HBase table such as the descriptors of
all the column families, is the table a catalog table, -ROOT-
or
hbase:meta
, if the table is read only, the maximum size of the memstore,
when the region split should occur, coprocessors associated with it etc...
- HTableDescriptor(TableName, HColumnDescriptor[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Private constructor used internally creating table descriptors for
catalog tables, hbase:meta
and -ROOT-
.
- HTableDescriptor(TableName, HColumnDescriptor[], Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Private constructor used internally creating table descriptors for
catalog tables, hbase:meta
and -ROOT-
.
- HTableDescriptor() - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
Used by Writables and Writables are going away.
- HTableDescriptor(TableName) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Construct a table descriptor specifying a TableName object
- HTableDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- HTableDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- HTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Construct a table descriptor by cloning the descriptor passed as a parameter.
- HTableFactory - Class in org.apache.hadoop.hbase.client
-
- HTableFactory() - Constructor for class org.apache.hadoop.hbase.client.HTableFactory
-
Deprecated.
- HTableInterface - Interface in org.apache.hadoop.hbase.client
-
Used to communicate with a single HBase table.
- HTableInterfaceFactory - Interface in org.apache.hadoop.hbase.client
-
Defines methods to create new HTableInterface.
- HTableMultiplexer - Class in org.apache.hadoop.hbase.client
-
HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.
- HTableMultiplexer(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- I - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'I'
- ID_ATRIBUTE - Static variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- ID_SIZE - Static variable in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- IdentityTableMap - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- IdentityTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableMap
-
Deprecated.
constructor
- IdentityTableMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Pass the given key and record as-is to the reduce phase.
- IdentityTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
-
- IdentityTableReduce - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- IdentityTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableReduce
-
Deprecated.
- IdentityTableReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Convenience class that simply writes all values (which must be
Put
or
Delete
instances)
passed to it out to the configured HBase table.
- IdentityTableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
-
- idx - Variable in class org.apache.hadoop.hbase.types.StructIterator
-
- ImmutableBytesWritable - Class in org.apache.hadoop.hbase.io
-
A byte sequence that is usable as a key or value.
- ImmutableBytesWritable() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Create a zero-size sequence.
- ImmutableBytesWritable(byte[]) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Create a ImmutableBytesWritable using the byte array as the initial value.
- ImmutableBytesWritable(ImmutableBytesWritable) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Set the new ImmutableBytesWritable to the contents of the passed
ibw
.
- ImmutableBytesWritable(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Set the value to a given byte range
- Import - Class in org.apache.hadoop.hbase.mapreduce
-
Import data written by
Export
.
- Import() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import
-
- ImportTsv - Class in org.apache.hadoop.hbase.mapreduce
-
Tool to import data from a TSV file.
- ImportTsv() - Constructor for class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Test if the given region is to be included in the InputSplit while
splitting the regions of a table.
- includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Test if the given region is to be included in the InputSplit while splitting
the regions of a table.
- includeTable(TableName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- InclusiveStopFilter - Class in org.apache.hadoop.hbase.filter
-
A Filter that stops after the given row.
- InclusiveStopFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- IncompatibleFilterException - Exception in org.apache.hadoop.hbase.filter
-
Used to indicate a filter incompatibility
- IncompatibleFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
-
constructor
- IncompatibleFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.IncompatibleFilterException
-
constructor
- increment(Increment) - Method in class org.apache.hadoop.hbase.client.HTable
-
Increments one or more columns within a single row.
- increment(Increment) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Increments one or more columns within a single row.
- Increment - Class in org.apache.hadoop.hbase.client
-
Used to perform Increment operations on a single row.
- Increment(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Create a Increment operation for the specified row.
- Increment(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Create a Increment operation for the specified row.
- Increment(Increment) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Copy constructor
- increment(Increment) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- incrementBytes(byte[], long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Bytewise binary increment/deincrement of long contained in byte array
on given amount.
- incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
-
- incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- incrementIv(byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- incrementIv(byte[], int) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- INDEX_KEY_MAGIC - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used as a magic return value while optimized index key feature enabled(HBASE-7845)
- indexOf(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns the index of the first appearance of the value target
in
array
.
- indexOf(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns the start position of the first occurrence of the specified target
within array
, or -1
if there is no such occurrence.
- inferBoundaries(TreeMap<byte[], Integer>) - Static method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- init(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Initialize the key provider
- init(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
Build the scanner.
- init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
Build the scanner.
- init() - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
-
Giving a chance for the initialization.
- initCredentials(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
- initCredentials(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
- initCredentialsForCluster(Job, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Obtain an authentication token, for the specified cluster, on behalf of the current user
and add it to the credentials for the given map reduce job.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Initializes the reader.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Build the scanner.
- initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
-
- initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner
-
- initJob(String, String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Deprecated.
Use this before submitting a TableMap job.
- initJob(String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
-
Deprecated.
Use this before submitting a TableMap job.
- initJob(String, Scan, String, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Use this before submitting a TableMap job.
- initJob(String, Scan, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
-
Use this before submitting a TableMap job.
- initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
Use this before submitting a TableMap job.
- initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
- initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<? extends WritableComparable>, Class<? extends Writable>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a Multi TableMap job.
- initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<? extends WritableComparable>, Class<? extends Writable>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a Multi TableMap job.
- initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<? extends WritableComparable>, Class<? extends Writable>, Job, boolean, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a Multi TableMap job.
- initTableReduceJob(String, Class<? extends TableReduce>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
Use this before submitting a TableReduce job.
- initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
Use this before submitting a TableReduce job.
- initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job, Class) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
Sets up the job for reading from a table snapshot.
- initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets up the job for reading from a table snapshot.
- injectNonceGeneratorForTesting(HConnection, NonceGenerator) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
- INPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Job parameter that specifies the input table.
- instantiateFilter(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Create a
Filter
to apply to all incoming keys (
KeyValues
) to
optionally not include in the job output
- InterfaceAudience - Class in org.apache.hadoop.hbase.classification
-
Annotation to inform users of a package, class or method's intended audience.
- InterfaceStability - Class in org.apache.hadoop.hbase.classification
-
Annotation to inform users of how much to rely on a particular package,
class or method not changing over time.
- InterfaceStability() - Constructor for class org.apache.hadoop.hbase.classification.InterfaceStability
-
- intFitsIn(int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Check how many bytes is required to store value.
- INVALID_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
-
Constant to denote invalid hash type.
- InvalidFamilyOperationException - Exception in org.apache.hadoop.hbase
-
Thrown if a request is table schema modification is requested but
made for an invalid family name.
- InvalidFamilyOperationException() - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
default constructor
- InvalidFamilyOperationException(String) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
Constructor
- InvalidFamilyOperationException(Exception) - Constructor for exception org.apache.hadoop.hbase.InvalidFamilyOperationException
-
Constructor taking another exception.
- InvalidRowFilterException - Exception in org.apache.hadoop.hbase.filter
-
Used to indicate an invalid RowFilter.
- InvalidRowFilterException() - Constructor for exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
-
constructor
- InvalidRowFilterException(String) - Constructor for exception org.apache.hadoop.hbase.filter.InvalidRowFilterException
-
constructor
- IS_META - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by rest interface to access this metadata
attribute which denotes if it is a catalog table, either
hbase:meta
or -ROOT-
- IS_ROOT - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by rest interface to access this metadata
attribute which denotes if the table is a -ROOT- region or not
- isAborted() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isAllTime() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Check if it is for all time
- isAutoFlush() - Method in class org.apache.hadoop.hbase.client.HTable
-
Tells whether or not 'auto-flush' is turned on.
- isAutoFlush() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Tells whether or not 'auto-flush' is turned on.
- isAutoFlush() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- isBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- isBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses BlobCopy
encoding, false otherwise.
- isBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses BlobVar
encoding, false otherwise.
- isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Query on the catalog janitor state (Enabled/Disabled?)
- isCheckExistenceOnly() - Method in class org.apache.hadoop.hbase.client.Get
-
- isClosed() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isClosestRowBefore() - Method in class org.apache.hadoop.hbase.client.Get
-
- isCompactionEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the compaction enable flag of the table is true.
- isCorrectEncoder(DataBlockEncoder, short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Check if given encoder has this id.
- isDeadServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isDeferredLogFlush() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- isDelete(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteColumns(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteColumnVersion(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDoNotRetry() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- isEmpty() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method to check if the familyMap is empty
- isEmpty() - Method in class org.apache.hadoop.hbase.client.Result
-
Check if the underlying Cell [] is empty or not
- isEmpty() - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
- isEmpty() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
- isEmpty() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- isEmpty(ByteRange) - Static method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- isEncodedValue(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Returns true when src
appears to be positioned an encoded value,
false otherwise.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Check that given column family is essential for filter to check row.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
The only CF this filter needs is given column family.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- isFixedFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width
Float32 encoding, false otherwise.
- isFixedFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width
Float64 encoding, false otherwise.
- isFixedInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width
Int32 encoding, false otherwise.
- isFixedInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width
Int64 encoding, false otherwise.
- isFullServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- isGetScan() - Method in class org.apache.hadoop.hbase.client.Scan
-
- isInMemory() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isLegalFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isLegalFullyQualifiedTableName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
Check passed byte array, "tableName", is legal user-space table name.
- isLegalNamespaceName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
- isLegalNamespaceName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
-
Valid namespace characters are [a-zA-Z_0-9]
- isLegalTableQualifierName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
- isLegalTableQualifierName(byte[], boolean) - Static method in class org.apache.hadoop.hbase.TableName
-
- isLegalTableQualifierName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
-
Qualifier names can only contain 'word' characters
[a-zA-Z_0-9]
or '_', '.' or '-'.
- isLegalTableQualifierName(byte[], int, int, boolean) - Static method in class org.apache.hadoop.hbase.TableName
-
- isLocal(Configuration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- isMasterRunning() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- isMetaRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isMetaRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Checks if this table is hbase:meta
region.
- isMetaTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isMetaTable() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Checks if the table is a hbase:meta
table
- isMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- isNull(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
is null, false
otherwise.
- isNullable() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Indicates whether this instance supports encoding null values.
- isNullable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawString
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.Struct
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.Union2
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.Union3
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.Union4
-
- isNumeric(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Numeric
encoding, false otherwise.
- isNumericInfinite(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Numeric
encoding and is Infinite
, false otherwise.
- isNumericNaN(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Numeric
encoding and is NaN
, false otherwise.
- isNumericZero(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Numeric
encoding and is 0
, false otherwise.
- isOffline() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- IsolationLevel - Enum in org.apache.hadoop.hbase.client
-
Specify Isolation levels in Scan operations.
- isOrderPreserving() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Indicates whether this instance writes encoded byte[]
's
which preserve the natural sort order of the unencoded value.
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawString
-
- isOrderPreserving - Variable in class org.apache.hadoop.hbase.types.Struct
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Struct
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union2
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union3
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union4
-
- isProcedureFinished(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Check the current state of the specified procedure.
- isQuoteUnescaped(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns a boolean indicating whether the quote was escaped or not
- isRaw() - Method in class org.apache.hadoop.hbase.client.Scan
-
- isReadOnly() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the readOnly flag of the table is set.
- isRecoverySupported() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- isRemote() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
The cause of a ForeignException can be an exception that was generated on a local in process
thread, or a thread from a 'remote' separate process.
- isReturnResults() - Method in class org.apache.hadoop.hbase.client.Append
-
- isReversed() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether this scan is a reversed one.
- isReversed() - Method in class org.apache.hadoop.hbase.filter.Filter
-
- isRootRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the descriptor represents a -ROOT-
region.
- isSameHostnameAndPort(ServerName, ServerName) - Static method in class org.apache.hadoop.hbase.ServerName
-
- isShowConfInServlet() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
- isSkippable() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Indicates whether this instance is able to skip over it's encoded value.
- isSkippable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.OrderedBlob
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawString
-
- isSkippable - Variable in class org.apache.hadoop.hbase.types.Struct
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Struct
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Union2
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Union3
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Union4
-
- isSmall() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether this scan is a small scan
- isSnapshotFinished(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Check the current state of the passed snapshot.
- isSorted(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- isSplit() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isSplitParent() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isSystemTable() - Method in class org.apache.hadoop.hbase.TableName
-
- isTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Use this api to check if the table has been created with the specified number of
splitkeys which was used while creating the given table.
- isTableAvailable(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(String, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isTableAvailable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Use this api to check if the table has been created with the specified number of
splitkeys which was used while creating the given table.
- isTableAvailable(byte[], byte[][]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableAvailable(String) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isTableDisabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
A table that isTableEnabled == false and isTableDisabled == false
is possible.
- isTableEnabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableEnabled(String) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(Configuration, String) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isText(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Text encoding,
false otherwise.
- iterateOnSplits(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Iterate over keys within the passed range, splitting at an [a,b) boundary.
- iterateOnSplits(byte[], byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Iterate over keys within the passed range.
- iterator(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
-
Retrieve an
Iterator
over the values encoded in
src
.
- iterator() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Run basic test.
- main(String[]) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
For debugging.
- main(String[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Test things basically work.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.Driver
-
Deprecated.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapred.RowCounter
-
Deprecated.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Driver
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
Main entry point.
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Main program.
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Main program
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRepair
-
Main program
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.JenkinsHash
-
Compute the hash of the specified file
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.Merge
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
- main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
-
Parse ZooKeeper configuration from HBase XML config and run a QuorumPeer.
- main(String[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKServerTool
-
Run the tool.
- MAJOR_COMPACTION_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for how often a region should should perform a major compaction
- majorCompact(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Major compact a table or an individual region.
- majorCompact(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Major compact a table or an individual region.
- majorCompact(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Major compact a column family within a table or region.
- majorCompact(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Major compact a column family within a table or region.
- map(ImmutableBytesWritable, Result, OutputCollector<ImmutableBytesWritable, Result>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Deprecated.
Extract the grouping columns from value to construct a new key.
- map(ImmutableBytesWritable, Result, OutputCollector<ImmutableBytesWritable, Result>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
-
Deprecated.
Pass the key, value to reduce
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Extract the grouping columns from value to construct a new key.
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Result>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
-
Pass the key, value to reduce.
- map(LongWritable, Text, Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Convert a line of TSV text into an HBase table row.
- map(LongWritable, Text, Mapper<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
Convert a line of TSV text into an HBase table row.
- mapKey(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- mapKey(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- MAPPER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- MASTER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- MASTER_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for what master implementation to use.
- MASTER_INFO_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for master web API port
- MASTER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for port master listens on.
- MASTER_TYPE_BACKUP - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the master type being backup (waits for primary to go inactive).
- MasterNotRunningException - Exception in org.apache.hadoop.hbase
-
Thrown if the master is not running
- MasterNotRunningException() - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
-
default constructor
- MasterNotRunningException(String) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
-
Constructor
- MasterNotRunningException(Exception) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
-
Constructor taking another exception.
- MasterNotRunningException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.MasterNotRunningException
-
- matchedColumn - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- matchingColumn(Cell, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingColumn(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingFamily(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingFamily(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingQualifier(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingQualifier(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingRow(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingRow(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingValue(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- matchingValue(Cell, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- MAX_CACHED_CONNECTION_INSTANCES - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager
-
- MAX_FILES_PER_REGION_PER_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by HBase Shell interface to access this metadata
attribute which denotes the maximum size of the store file after which
a region split occurs
- MAX_PRECISION - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
-
Max precision guaranteed to fit into a long
.
- MAX_ROW_LENGTH - Static variable in class org.apache.hadoop.hbase.HConstants
-
Max length a row can have because of the limitation in TFile.
- maxColumn - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- maxColumnInclusive - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- MAXIMUM_VALUE_LENGTH - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum value length, enforced on KeyValue construction
- maxScannerResultSize - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- mayHaveClusterIssues() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- MD5_HEX_LENGTH - Static variable in class org.apache.hadoop.hbase.HRegionInfo
-
- MD5Hash - Class in org.apache.hadoop.hbase.util
-
Utility class for MD5
MD5 hash produces a 128-bit digest.
- MD5Hash() - Constructor for class org.apache.hadoop.hbase.util.MD5Hash
-
- MEMSTORE_FLUSHSIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by HBase Shell interface to access this metadata
attribute which represents the maximum size of the memstore after which
its contents are flushed onto the disk
- merge(Configuration, Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Merge two configurations.
- Merge - Class in org.apache.hadoop.hbase.util
-
Utility that can merge any two regions in the same table: adjacent,
overlapping or disjoint.
- Merge() - Constructor for class org.apache.hadoop.hbase.util.Merge
-
default constructor
- Merge(Configuration) - Constructor for class org.apache.hadoop.hbase.util.Merge
-
- MERGEA_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The lower-half merge region column qualifier
- MERGEB_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The upper-half merge region column qualifier
- mergeRegionDirs(Path, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Merge hdfs data by moving from contained HbckInfo into targetRegionDir.
- MergeRegionException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when something is wrong in trying to merge two regions.
- MergeRegionException() - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
-
default constructor
- MergeRegionException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.MergeRegionException
-
Constructor
- mergeRegions(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Merge two regions.
- META_ROW_DELIMITER - Static variable in class org.apache.hadoop.hbase.HConstants
-
delimiter used between portions of a region name
- META_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.
- META_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.TableName
-
The hbase:meta table's name.
- META_TABLEDESC - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Table descriptor for hbase:meta
catalog table
- META_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
-
The current version of the meta table.
- META_VERSION_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The meta table version column qualifier.
- METADATA - Static variable in class org.apache.hadoop.hbase.HConstants
-
- METRICS_RIT_STUCK_WARNING_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
Region in Transition metrics threshold time
- MIGRATION_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Any artifacts left from migration can be moved here
- MIMETYPE_BINARY - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIMETYPE_HTML - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIMETYPE_JSON - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIMETYPE_PROTOBUF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIMETYPE_PROTOBUF_IETF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIMETYPE_TEXT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIMETYPE_XML - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- minColumn - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- minColumnInclusive - Variable in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- MiniZooKeeperCluster - Class in org.apache.hadoop.hbase.zookeeper
-
TODO: Most of the code in this class is ripped from ZooKeeper tests.
- MiniZooKeeperCluster() - Constructor for class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- MiniZooKeeperCluster(Configuration) - Constructor for class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- MINUS_SIGN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII for Minus Sign
- MINUTE_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- modifyColumn(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Modify an existing column family on a table.
- modifyColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Modify an existing column family on a table.
- modifyColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Modify an existing column family on a table.
- modifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Modify an existing namespace
- modifyTable(TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Modify an existing table, more IRB friendly version.
- modifyTable(byte[], HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- modifyTable(String, HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- move(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Move the region r
to dest
.
- moveBufferToStream(OutputStream, ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy the data to the output stream and update position in buffer.
- multiple(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create a byte array which is multiple given bytes
- MultipleColumnPrefixFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used for selecting only those keys with columns that matches
a particular prefix.
- MultipleColumnPrefixFilter(byte[][]) - Constructor for class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- MultiTableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Convert HBase tabular data from multiple scanners into a format that
is consumable by Map/Reduce.
- MultiTableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
- MultiTableInputFormatBase - Class in org.apache.hadoop.hbase.mapreduce
-
- MultiTableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
- MultiTableOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Hadoop output format that writes to one or more HBase tables.
- MultiTableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- MURMUR_HASH - Static variable in class org.apache.hadoop.hbase.util.Hash
-
- MURMUR_HASH3 - Static variable in class org.apache.hadoop.hbase.util.Hash
-
Constant to denote MurmurHash3
.
- MurmurHash - Class in org.apache.hadoop.hbase.util
-
This is a very fast, non-cryptographic hash suitable for general hash-based
lookup.
- MurmurHash() - Constructor for class org.apache.hadoop.hbase.util.MurmurHash
-
- mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
-
Performs multiple mutations atomically on a single row.
- mutateRow(RowMutations) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Performs multiple mutations atomically on a single row.
- mutateRow(RowMutations) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- Mutation - Class in org.apache.hadoop.hbase.client
-
- Mutation() - Constructor for class org.apache.hadoop.hbase.client.Mutation
-
- MUTATION_OVERHEAD - Static variable in class org.apache.hadoop.hbase.client.Mutation
-
- P - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'P'
- padHead(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- padTail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- PageFilter - Class in org.apache.hadoop.hbase.filter
-
Implementation of Filter interface that limits results to a specific page
size.
- PageFilter(long) - Constructor for class org.apache.hadoop.hbase.filter.PageFilter
-
Constructor that takes a maximum page size.
- Pair<T1,T2> - Class in org.apache.hadoop.hbase.util
-
A generic class for pairs.
- Pair() - Constructor for class org.apache.hadoop.hbase.util.Pair
-
Default constructor.
- Pair(T1, T2) - Constructor for class org.apache.hadoop.hbase.util.Pair
-
Constructor
- PairOfSameType<T> - Class in org.apache.hadoop.hbase.util
-
A generic, immutable class for pairs of objects both of type T
.
- PairOfSameType(T, T) - Constructor for class org.apache.hadoop.hbase.util.PairOfSameType
-
Constructor
- parseComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Splits a column in comparatorType:comparatorValue form into separate byte arrays
- ParseConstants - Class in org.apache.hadoop.hbase.filter
-
ParseConstants holds a bunch of constants related to parsing Filter Strings
Used by
ParseFilter
- ParseConstants() - Constructor for class org.apache.hadoop.hbase.filter.ParseConstants
-
- parseDelimitedFrom(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Parses all the HRegionInfo instances from the passed in stream until EOF.
- ParseFilter - Class in org.apache.hadoop.hbase.filter
-
This class allows a user to specify a filter via a string
The string is parsed using the methods of this class and
a filter object is constructed.
- ParseFilter() - Constructor for class org.apache.hadoop.hbase.filter.ParseFilter
-
- parseFilterString(String) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Parses the filterString and constructs a filter using it
- parseFilterString(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Parses the filterString and constructs a filter using it
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.BitComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.Filter
-
Concrete implementers can signal a failure condition in their code by throwing an
IOException
.
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FilterList
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.NullComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- parseFrom(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- parseFrom(DataInputStream) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Parses an HRegionInfo instance from the passed in stream.
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
- parseFrom(byte[]) - Static method in class org.apache.hadoop.hbase.ServerName
-
Get a ServerName from the passed in data bytes.
- parseFromOrNull(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- parseFromOrNull(byte[], int, int) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- parseHashType(String) - Static method in class org.apache.hadoop.hbase.util.Hash
-
This utility method converts String representation of hash function name
to a symbolic constant.
- parseHostname(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- parseOptions(String[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- parsePort(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- parser - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- parseRegionName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Separate elements of a regionName.
- parseServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- parseSimpleFilterExpression(byte[]) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Constructs a filter object given a simple filter expression
- parseStartcode(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- parseVersionedServerName(byte[]) - Static method in class org.apache.hadoop.hbase.ServerName
-
- passedPrefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- PASSWORD - Static variable in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
- password - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- PASSWORDFILE - Static variable in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
- passwordFile - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- path - Static variable in class org.apache.hadoop.hbase.util.CompressionTest
-
- pbkdf128(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a 128 bit key derived from the concatenation of the supplied
arguments using PBKDF2WithHmacSHA1 at 10,000 iterations.
- pbkdf128(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return a 128 bit key derived from the concatenation of the supplied
arguments using PBKDF2WithHmacSHA1 at 10,000 iterations.
- peek() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next byte from this range without incrementing position.
- peek() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- PHOENIX - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
- PleaseHoldException - Exception in org.apache.hadoop.hbase
-
This exception is thrown by the master when a region server was shut down and
restarted so fast that the master still hasn't processed the server shutdown
of the first instance, or when master is initializing and client call admin
operations, or when an operation is performed on a region server that is still starting.
- PleaseHoldException(String) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
-
- PleaseHoldException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
-
- PleaseHoldException(Throwable) - Constructor for exception org.apache.hadoop.hbase.PleaseHoldException
-
- pluralize(Collection<?>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- pluralize(int) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- popArguments(Stack<ByteBuffer>, Stack<Filter>) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Pops an argument from the operator stack and the number of arguments required by the operator
from the filterStack and evaluates them
- populatePut(byte[], ImportTsv.TsvParser.ParsedLine, Put, int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- PositionedByteRange - Interface in org.apache.hadoop.hbase.util
-
Extends
ByteRange
with additional methods to support tracking a
consumers position within the viewport.
- post(String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(Cluster, String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- post(Cluster, String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a POST request
- PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Key for the PREFETCH_BLOCKS_ON_OPEN attribute.
- prefix - Variable in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- prefix - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- PrefixFilter - Class in org.apache.hadoop.hbase.filter
-
Pass results that have same row prefix.
- PrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.PrefixFilter
-
- prepare(boolean) - Method in class org.apache.hadoop.hbase.client.ReversedScannerCallable
-
- prettyPrint(String) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Use logging.
- PrettyPrinter - Class in org.apache.hadoop.hbase.util
-
- PrettyPrinter() - Constructor for class org.apache.hadoop.hbase.util.PrettyPrinter
-
- printUsageAndExit() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- printUsageAndExit() - Static method in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRepair
-
- processBatch(List<? extends Row>, TableName, ExecutorService, Object[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- processBatch(List<? extends Row>, byte[], ExecutorService, Object[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- processBatch(List<? extends Row>, Object[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Parameterized batch processing, allowing varying return types for different
Row
implementations.
- processBatchCallback(List<? extends Row>, TableName, ExecutorService, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- processBatchCallback(List<? extends Row>, byte[], ExecutorService, Object[], Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- processBatchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Process a mixed batch of Get, Put and Delete actions.
- processFile(Configuration, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
reads a log file and outputs its contents, one transaction at a time, as
specified by the currently configured options
- processParameter(String, String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- processParameters(URI) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- put(Put) - Method in class org.apache.hadoop.hbase.client.HTable
-
Puts some data in the table.
- put(List<Put>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Puts some data in the table, in batch.
- put(Put) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Puts some data in the table.
- put(List<Put>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Puts some data in the table, in batch.
- put(TableName, Put) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
The put request will be buffered by its corresponding buffer queue.
- put(TableName, List<Put>) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
The puts request will be buffered by their corresponding buffer queue.
- put(byte[], List<Put>) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- put(TableName, Put, int) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
The put request will be buffered by its corresponding buffer queue.
- put(byte[], Put, int) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- put(byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
Deprecated.
- Put - Class in org.apache.hadoop.hbase.client
-
Used to perform Put operations for a single row.
- Put(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Create a Put operation for the specified row.
- Put(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Create a Put operation for the specified row, using a given timestamp.
- Put(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Put
-
We make a copy of the passed in row key to keep local.
- Put(ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.client.Put
-
- Put(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.client.Put
-
- Put(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.client.Put
-
We make a copy of the passed in row key to keep local.
- Put(Put) - Constructor for class org.apache.hadoop.hbase.client.Put
-
Copy constructor.
- put(String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(Cluster, String, String, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(Cluster, String, Header[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a PUT request
- put(Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- put(List<Put>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- put(int, byte) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store val
at index
.
- put(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store val
at index
.
- put(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Store length
bytes from val
into this range, starting at
index
.
- put(byte) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store val
at the next position in this range.
- put(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store the content of val
in this range, starting at the next position.
- put(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Store length
bytes from val
into this range.
- put(int, byte) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- put(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- put(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- put(byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- put(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- put(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- put(int, byte) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- put(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- put(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- putAsShort(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put an int value as short out to the specified byte array position.
- putBigDecimal(byte[], int, BigDecimal) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a BigDecimal value out to the specified byte array position.
- putByte(byte[], int, byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write a single byte out to the specified byte array position.
- putByteBuffer(byte[], int, ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Add the whole content of the ByteBuffer to the bytes arrays.
- putBytes(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put bytes at the specified byte array position.
- PutCombiner<K> - Class in org.apache.hadoop.hbase.mapreduce
-
Combine Puts.
- PutCombiner() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutCombiner
-
- putCompressedInt(OutputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Put in buffer integer using 7 bit encoding.
- putDouble(byte[], int, double) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- putFloat(byte[], int, float) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- putInt(OutputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Put in output stream 32 bit integer (Big Endian byte order).
- putInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put an int value out to the specified byte array position.
- putIntUnsafe(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put an int value out to the specified byte array position (Unsafe).
- putLong(OutputStream, long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
- putLong(byte[], int, long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a long value out to the specified byte array position.
- putLongUnsafe(byte[], int, long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a long value out to the specified byte array position (Unsafe).
- putShort(byte[], int, short) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a short value out to the specified byte array position.
- putShortUnsafe(byte[], int, short) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Put a short value out to the specified byte array position (Unsafe).
- PutSortReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Emits sorted Puts.
- PutSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.PutSortReducer
-
- R - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'R'
- random - Static variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- random(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Fill given array with random bytes.
- random(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Fill given array with random bytes at the specified position.
- RandomRowFilter - Class in org.apache.hadoop.hbase.filter
-
A filter that includes rows based on a chance.
- RandomRowFilter(float) - Constructor for class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Create a new filter with a specified chance for a row to be included.
- raw() - Method in class org.apache.hadoop.hbase.client.Result
-
- RawByte - Class in org.apache.hadoop.hbase.types
-
- RawByte() - Constructor for class org.apache.hadoop.hbase.types.RawByte
-
- RawBytes - Class in org.apache.hadoop.hbase.types
-
- RawBytes() - Constructor for class org.apache.hadoop.hbase.types.RawBytes
-
- RawBytes(Order) - Constructor for class org.apache.hadoop.hbase.types.RawBytes
-
- RawBytesFixedLength - Class in org.apache.hadoop.hbase.types
-
- RawBytesFixedLength(Order, int) - Constructor for class org.apache.hadoop.hbase.types.RawBytesFixedLength
-
Create a RawBytesFixedLength
using the specified order
and length
.
- RawBytesFixedLength(int) - Constructor for class org.apache.hadoop.hbase.types.RawBytesFixedLength
-
Create a RawBytesFixedLength
of the specified length
.
- RawBytesTerminated - Class in org.apache.hadoop.hbase.types
-
- RawBytesTerminated(Order, byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Create a RawBytesTerminated
using the specified terminator and
order
.
- RawBytesTerminated(Order, String) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Create a RawBytesTerminated
using the specified terminator and
order
.
- RawBytesTerminated(byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Create a RawBytesTerminated
using the specified terminator.
- RawBytesTerminated(String) - Constructor for class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Create a RawBytesTerminated
using the specified terminator.
- rawCells() - Method in class org.apache.hadoop.hbase.client.Result
-
Return the array of Cells backing this Result instance.
- RawDouble - Class in org.apache.hadoop.hbase.types
-
- RawDouble() - Constructor for class org.apache.hadoop.hbase.types.RawDouble
-
- RawFloat - Class in org.apache.hadoop.hbase.types
-
- RawFloat() - Constructor for class org.apache.hadoop.hbase.types.RawFloat
-
- RawInteger - Class in org.apache.hadoop.hbase.types
-
- RawInteger() - Constructor for class org.apache.hadoop.hbase.types.RawInteger
-
- RawLong - Class in org.apache.hadoop.hbase.types
-
- RawLong() - Constructor for class org.apache.hadoop.hbase.types.RawLong
-
- RawShort - Class in org.apache.hadoop.hbase.types
-
- RawShort() - Constructor for class org.apache.hadoop.hbase.types.RawShort
-
- RawString - Class in org.apache.hadoop.hbase.types
-
- RawString() - Constructor for class org.apache.hadoop.hbase.types.RawString
-
- RawString(Order) - Constructor for class org.apache.hadoop.hbase.types.RawString
-
- RawStringFixedLength - Class in org.apache.hadoop.hbase.types
-
- RawStringFixedLength(Order, int) - Constructor for class org.apache.hadoop.hbase.types.RawStringFixedLength
-
Create a RawStringFixedLength
using the specified
order
and length
.
- RawStringFixedLength(int) - Constructor for class org.apache.hadoop.hbase.types.RawStringFixedLength
-
Create a RawStringFixedLength
of the specified length
.
- RawStringTerminated - Class in org.apache.hadoop.hbase.types
-
- RawStringTerminated(Order, byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
-
Create a RawStringTerminated
using the specified terminator and
order
.
- RawStringTerminated(Order, String) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
-
Create a RawStringTerminated
using the specified terminator and
order
.
- RawStringTerminated(byte[]) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
-
Create a RawStringTerminated
using the specified terminator.
- RawStringTerminated(String) - Constructor for class org.apache.hadoop.hbase.types.RawStringTerminated
-
Create a RawStringTerminated
using the specified terminator.
- read() - Method in class org.apache.hadoop.hbase.util.Base64.Base64InputStream
-
Reads enough of the input stream to convert to/from Base64 and returns
the next byte.
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Base64.Base64InputStream
-
- readAsInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to an int value
- readByteArray(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Read byte-array written with a WritableableUtils.vint prefix.
- readByteArrayThrowsRuntime(DataInput) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Read byte-array written with a WritableableUtils.vint prefix.
- readCompressedInt(InputStream) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Read integer from stream coded in 7 bits and increment position.
- readCompressedInt(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Read integer from buffer coded in 7 bits and increment position.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Use protobuf deserialization instead.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Reads the values of each field.
- readLong(InputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Read long which was written to fitInBytes bytes and increment position.
- readLong(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Read long which was written to fitInBytes bytes and increment position.
- READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by rest interface to access this metadata
attribute which denotes if the table is Read Only
- readStringFixedSize(DataInput, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Reads a fixed-size field and interprets it as a string padded with zeros.
- readVLong(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Similar to
WritableUtils.readVLong(DataInput)
but reads from a
ByteBuffer
.
- readVLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Reads a zero-compressed encoded long from input stream and returns it.
- rebuildMeta(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Rebuilds meta from information in hdfs/fs.
- RECOVERED_EDITS_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
-
- recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- reduce(Stack<ByteBuffer>, Stack<Filter>, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
This function is called while parsing the filterString and an operator is parsed
- reduce(ImmutableBytesWritable, Iterator<Put>, OutputCollector<ImmutableBytesWritable, Put>, Reporter) - Method in class org.apache.hadoop.hbase.mapred.IdentityTableReduce
-
Deprecated.
No aggregation, output pairs of (key, record)
- reduce(Writable, Iterable<Mutation>, Reducer<Writable, Mutation, Writable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
-
Writes each given record, consisting of the row key and the given values,
to the configured OutputFormat
.
- reduce(ImmutableBytesWritable, Iterable<KeyValue>, Reducer<ImmutableBytesWritable, KeyValue, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSortReducer
-
- reduce(K, Iterable<Put>, Reducer<K, Put, K, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutCombiner
-
- reduce(ImmutableBytesWritable, Iterable<Put>, Reducer<ImmutableBytesWritable, Put, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutSortReducer
-
- reduce(ImmutableBytesWritable, Iterable<Text>, Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- RegexStringComparator - Class in org.apache.hadoop.hbase.filter
-
- RegexStringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor
Adds Pattern.DOTALL to the underlying Pattern
- RegexStringComparator(String, RegexStringComparator.EngineType) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor
Adds Pattern.DOTALL to the underlying Pattern
- RegexStringComparator(String, int) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor
- RegexStringComparator(String, int, RegexStringComparator.EngineType) - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Constructor
- regexStringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
RegexStringType byte array
- REGION_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REGION_SERVER_CLASS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Optional specification of the rs class name of the peer cluster
- REGION_SERVER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REGION_SERVER_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for what region server implementation to use.
- REGION_SERVER_IMPL - Static variable in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Optional specification of the rs impl name of the peer cluster
- REGION_SERVER_META_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REGION_SERVER_REPLICATION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- RegionAlreadyInTransitionException - Exception in org.apache.hadoop.hbase.regionserver
-
This exception is thrown when a region server is asked to open or close
a region but it's already processing it
- RegionAlreadyInTransitionException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionAlreadyInTransitionException
-
- RegionException - Exception in org.apache.hadoop.hbase
-
Thrown when something happens related to region handling.
- RegionException() - Constructor for exception org.apache.hadoop.hbase.RegionException
-
default constructor
- RegionException(String) - Constructor for exception org.apache.hadoop.hbase.RegionException
-
Constructor
- REGIONINFO_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The regioninfo column qualifier
- REGIONINFO_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The RegionInfo qualifier as a string
- RegionInRecoveryException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when a read request issued against a region which is in recovering state.
- RegionInRecoveryException() - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionInRecoveryException
-
default constructor
- RegionInRecoveryException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.RegionInRecoveryException
-
Constructor
- RegionLoad - Class in org.apache.hadoop.hbase
-
Encapsulates per-region load metrics.
- RegionLoad(ClusterStatusProtos.RegionLoad) - Constructor for class org.apache.hadoop.hbase.RegionLoad
-
- regionLoadPB - Variable in class org.apache.hadoop.hbase.RegionLoad
-
- RegionOfflineException - Exception in org.apache.hadoop.hbase.client
-
Thrown when a table can not be located
- RegionOfflineException() - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
-
default constructor
- RegionOfflineException(String) - Constructor for exception org.apache.hadoop.hbase.client.RegionOfflineException
-
- REGIONSERVER_INFO_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
A configuration key for regionserver info port
- REGIONSERVER_INFO_PORT_AUTO - Static variable in class org.apache.hadoop.hbase.HConstants
-
A flag that enables automatic selection of regionserver info port
- REGIONSERVER_METRICS_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
The period (in milliseconds) between computing region server point in time metrics
- REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for port region server listens on.
- RegionServerRunningException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown if the region server log directory exists (which indicates another
region server is running at the same address)
- RegionServerRunningException() - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
-
Default Constructor
- RegionServerRunningException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerRunningException
-
Constructs the exception and supplies a string as the message
- RegionServerStoppedException - Exception in org.apache.hadoop.hbase.regionserver
-
Thrown by the region server when it is in shutting down state.
- RegionServerStoppedException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.RegionServerStoppedException
-
- RegionState.State - Enum in org.apache.hadoop.hbase.master
-
- RegionTooBusyException - Exception in org.apache.hadoop.hbase
-
Thrown by a region server if it will block and wait to serve a request.
- RegionTooBusyException() - Constructor for exception org.apache.hadoop.hbase.RegionTooBusyException
-
default constructor
- RegionTooBusyException(String) - Constructor for exception org.apache.hadoop.hbase.RegionTooBusyException
-
Constructor
- registerFilter(String, String) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Register a new filter with the parser.
- releaseHTableInterface(HTableInterface) - Method in class org.apache.hadoop.hbase.client.HTableFactory
-
Deprecated.
- releaseHTableInterface(HTableInterface) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
-
Release the HTable resource represented by the table.
- relocateRegion(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Find the location of the region of tableName that row
lives in, ignoring any value that might be in the cache.
- relocateRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- RemoteAdmin - Class in org.apache.hadoop.hbase.rest.client
-
- RemoteAdmin(Client, Configuration) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
Constructor
- RemoteAdmin(Client, Configuration, String) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
Constructor
- RemoteHTable - Class in org.apache.hadoop.hbase.rest.client
-
HTable interface to remote tables accessed via REST gateway
- RemoteHTable(Client, String) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
Constructor
- RemoteHTable(Client, Configuration, String) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
Constructor
- RemoteHTable(Client, Configuration, byte[]) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
Constructor
- RemoteWithExtrasException - Exception in org.apache.hadoop.hbase.ipc
-
A RemoteException
with some extra information.
- RemoteWithExtrasException(String, String, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- RemoteWithExtrasException(String, String, String, int, boolean) - Constructor for exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- remove(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- remove(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- remove(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- remove(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- remove(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Remove a node from the cluster
- remove(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Remove a node from the cluster
- remove() - Method in class org.apache.hadoop.hbase.types.StructIterator
-
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- removeConfiguration(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Remove a coprocessor from those set on the table
- removeExtraHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Remove an extra header.
- removeFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- removeFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Removes the HColumnDescriptor with name specified by the parameter column
from the table descriptor
- removePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Removes a peer cluster and stops the replication to it.
- removeQuotesFromByteArray(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Takes a quoted byte array and converts it into an unquoted byte array
For example: given a byte array representing 'abc', it returns a
byte array representing abc
- REPLAY_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_CODEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for setting replication codec class name
- REPLICATION_ENABLE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_ENABLE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- REPLICATION_SCOPE_BYTES - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- REPLICATION_SCOPE_GLOBAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Scope tag for globally scoped data.
- REPLICATION_SCOPE_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Scope tag for locally scoped data.
- REPLICATION_SERVICE_CLASSNAME_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_SINK_SERVICE_CLASSNAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_SOURCE_SERVICE_CLASSNAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- ReplicationAdmin - Class in org.apache.hadoop.hbase.client.replication
-
This class provides the administrative interface to HBase cluster
replication.
- ReplicationAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Constructor that creates a connection to the local ZooKeeper ensemble.
- ReplicationException - Exception in org.apache.hadoop.hbase.replication
-
An HBase Replication exception.
- ReplicationException() - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
-
- ReplicationException(String) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
-
- ReplicationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
-
- ReplicationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.replication.ReplicationException
-
- REPLICATIONGLOBAL - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- REPLICATIONTYPE - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- RESERVED_NAMESPACES - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- RESERVED_NAMESPACES_BYTES - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- reset() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.Filter
-
Reset the state of the filter between rows.
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- reset() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.RowFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- reset() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- reset() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Reset state, reinitialize with the key and iv
- reset() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Reset state, reinitialize with the key and iv
- reset() - Method in class org.apache.hadoop.hbase.types.StructBuilder
-
Reset the sequence of accumulated fields.
- resetCacheConfig(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Enable a basic on-heap cache for these jobs.
- Response - Class in org.apache.hadoop.hbase.rest.client
-
The HTTP result code, response headers, and body of a HTTP response.
- Response(int) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
-
Constructor
- Response(int, Header[]) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
-
Constructor
- Response(int, Header[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
-
Constructor
- Response(int, Header[], byte[], InputStream) - Constructor for class org.apache.hadoop.hbase.rest.client.Response
-
Constructor
- REST_AUTHENTICATION_PRINCIPAL - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_AUTHENTICATION_TYPE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_DNS_INTERFACE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_DNS_NAMESERVER - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_KERBEROS_PRINCIPAL - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_KEYTAB_FILE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_ENABLED - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_KEYSTORE_KEYPASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_KEYSTORE_PASSWORD - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- REST_SSL_KEYSTORE_STORE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
Restart from survivable exceptions by creating a new scanner.
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
Restart from survivable exceptions by creating a new scanner.
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Restart from survivable exceptions by creating a new scanner.
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Restart from survivable exceptions by creating a new scanner.
- restoreSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Restore the specified snapshot on the original table.
- RestoreSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot could not be restored due to a server-side error when restoring it.
- RestoreSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- RestoreSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- RestoreSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- RestoreSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.RestoreSnapshotException
-
- Result - Class in org.apache.hadoop.hbase.client
-
Single row result of a
Get
or
Scan
query.
- Result() - Constructor for class org.apache.hadoop.hbase.client.Result
-
Creates an empty Result w/ no KeyValue payload; returns null if you call
Result.rawCells()
.
- Result(KeyValue[]) - Constructor for class org.apache.hadoop.hbase.client.Result
-
- Result(List<KeyValue>) - Constructor for class org.apache.hadoop.hbase.client.Result
-
- ResultScanner - Interface in org.apache.hadoop.hbase.client
-
Interface for client-side scanning.
- RETRIES_BY_SERVER_KEY - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager
-
- RetriesExhaustedException - Exception in org.apache.hadoop.hbase.client
-
Exception thrown by HTable methods when an attempt to do something (like
commit changes) fails after a bunch of retries.
- RetriesExhaustedException(String) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
- RetriesExhaustedException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
- RetriesExhaustedException(String, int, List<Throwable>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
Create a new RetriesExhaustedException from the list of prior failures.
- RetriesExhaustedException(int, List<RetriesExhaustedException.ThrowableWithExtraContext>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
Create a new RetriesExhaustedException from the list of prior failures.
- RetriesExhaustedWithDetailsException - Exception in org.apache.hadoop.hbase.client
-
This subclass of
RetriesExhaustedException
is thrown when we have more information about which rows were causing which
exceptions on what servers.
- RetriesExhaustedWithDetailsException(List<Throwable>, List<? extends Row>, List<String>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- retrieveGetCounterWithStringsParams(TaskAttemptContext) - Static method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
In new mapreduce APIs, TaskAttemptContext has two getCounter methods
Check if getCounter(String, String) method is available.
- RETRY_BACKOFF - Static variable in class org.apache.hadoop.hbase.HConstants
-
Retrying we multiply hbase.client.pause setting by what we have in this array until we
run out of array items.
- returnCompressor(Compressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- returnDecompressor(Decompressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- reversed - Variable in class org.apache.hadoop.hbase.filter.Filter
-
- ReversedClientScanner - Class in org.apache.hadoop.hbase.client
-
A reversed client scanner which support backward scanning
- ReversedClientScanner(Configuration, Scan, TableName, HConnection) - Constructor for class org.apache.hadoop.hbase.client.ReversedClientScanner
-
Create a new ReversibleClientScanner for the specified table Note that the
passed
Scan
's start row maybe changed.
- reverseDNS(InetAddress) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- ReversedScannerCallable - Class in org.apache.hadoop.hbase.client
-
A reversed ScannerCallable which supports backward scanning.
- ReversedScannerCallable(HConnection, TableName, Scan, ScanMetrics, byte[]) - Constructor for class org.apache.hadoop.hbase.client.ReversedScannerCallable
-
Deprecated.
- ReversedScannerCallable(HConnection, TableName, Scan, ScanMetrics, byte[], PayloadCarryingRpcController) - Constructor for class org.apache.hadoop.hbase.client.ReversedScannerCallable
-
- rollHLogWriter(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Roll the log writer.
- row - Variable in class org.apache.hadoop.hbase.client.Mutation
-
- Row - Interface in org.apache.hadoop.hbase.client
-
Has a row.
- ROW_KEYS_PARAM_NAME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- RowCounter - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- RowCounter() - Constructor for class org.apache.hadoop.hbase.mapred.RowCounter
-
Deprecated.
- RowCounter - Class in org.apache.hadoop.hbase.mapreduce
-
A job with a just a map phase to count rows.
- RowCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.RowCounter
-
- RowFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter based on the key.
- RowFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.RowFilter
-
Constructor.
- RowMutations - Class in org.apache.hadoop.hbase.client
-
Performs multiple mutations atomically on a single row.
- RowMutations() - Constructor for class org.apache.hadoop.hbase.client.RowMutations
-
Constructor for Writable.
- RowMutations(byte[]) - Constructor for class org.apache.hadoop.hbase.client.RowMutations
-
Create an atomic mutation for the specified row.
- RPAREN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for RPAREN
- RPC_CODEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for setting RPC codec class name
- RPC_CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
-
- RPC_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The first four bytes of Hadoop RPC connections
- RpcClient.CallTimeoutException - Exception in org.apache.hadoop.hbase.ipc
-
Client-side call timeout
- RpcClient.CallTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.RpcClient.CallTimeoutException
-
- RpcClient.FailedServerException - Exception in org.apache.hadoop.hbase.ipc
-
- RpcClient.FailedServerException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.RpcClient.FailedServerException
-
- rpcControllerFactory - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- run(String[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
Runs the command-line pretty-printer, and returns the desired command
exit code (zero for success, non-zero for failure).
- run(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
-
Deprecated.
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
- run(String[]) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- run(String[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
Pass one or more log file names and formatting options and it will dump out
a text version of the contents on stdout
.
- run(String[]) - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
Execute the export snapshot by copying the snapshot metadata, hfiles and hlogs.
- run(String[]) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.Merge
-
- runCatalogScan() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Ask for a scan of the catalog table
- S - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'S'
- scan - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- Scan - Class in org.apache.hadoop.hbase.client
-
Used to perform Scan operations.
- Scan() - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Create a Scan operation across all rows.
- Scan(byte[], Filter) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
- Scan(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Create a Scan operation starting at the specified row.
- Scan(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Create a Scan operation for the range of rows specified.
- Scan(Scan) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Creates a new instance of this class while copying all values.
- Scan(Get) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Builds a scan object with the same specs as get.
- SCAN - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Base-64 encoded scanner.
- SCAN_ATTRIBUTES_METRICS_DATA - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- SCAN_ATTRIBUTES_METRICS_ENABLE - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- SCAN_ATTRIBUTES_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- SCAN_BATCH_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_BATCHSIZE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Set the maximum number of values to return for each call to next().
- SCAN_CACHEBLOCKS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Set to false to disable server-side caching of blocks for this scan.
- SCAN_CACHEDROWS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The number of rows for caching that will be passed to scanners.
- SCAN_COLUMN - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_COLUMN_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Column Family to Scan
- SCAN_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Space delimited list of columns and column families to scan.
- SCAN_END_ROW - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_END_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_FETCH_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_LIMIT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_MAX_VERSIONS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_MAXVERSIONS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The maximum number of version to return.
- SCAN_ROW_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Scan start row
- SCAN_ROW_STOP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Scan stop row
- SCAN_START_ROW - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_START_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_TIMERANGE_END - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The ending timestamp used to filter columns with a specific range of versions.
- SCAN_TIMERANGE_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The starting timestamp used to filter columns with a specific range of versions.
- SCAN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The timestamp used to filter columns with a specific timestamp.
- scanMetricsPublished - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- scannerCaching - Variable in class org.apache.hadoop.hbase.client.HTable
-
- scannerTimeout - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- ScannerTimeoutException - Exception in org.apache.hadoop.hbase.client
-
Thrown when a scanner has timed out.
- SCANS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Job parameter that specifies the scan list.
- second - Variable in class org.apache.hadoop.hbase.util.Pair
-
- SEPARATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- SEQNUM_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The open seqnum column qualifier
- serialize(String, Throwable) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Converts a ForeignException to an array of bytes.
- SERVER_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The server column qualifier
- ServerLoad - Class in org.apache.hadoop.hbase
-
This class is used for exporting current state of load on a RegionServer.
- ServerLoad(ClusterStatusProtos.ServerLoad) - Constructor for class org.apache.hadoop.hbase.ServerLoad
-
- serverLoad - Variable in class org.apache.hadoop.hbase.ServerLoad
-
- ServerName - Class in org.apache.hadoop.hbase
-
Instance of an HBase ServerName.
- SERVERNAME_PATTERN - Static variable in class org.apache.hadoop.hbase.ServerName
-
- SERVERNAME_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The serverName column qualifier.
- SERVERNAME_SEPARATOR - Static variable in class org.apache.hadoop.hbase.ServerName
-
This character is used as separator between server hostname, port and
startcode.
- ServerNotRunningYetException - Exception in org.apache.hadoop.hbase.ipc
-
- ServerNotRunningYetException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- set(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Reuse this ByteRange
over a new byte[].
- set(byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Reuse this ByteRange
over a new byte[].
- set(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Reuse this ByteRange
over a new byte[].
- set(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- set(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- set(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- set(int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- set(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Query
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Query
-
- setACLStrategy(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setACLStrategy(boolean) - Method in class org.apache.hadoop.hbase.client.Query
-
- setAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Sets an attribute.
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Query
-
Sets the authorizations to be used by this Query
- setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- setAutoFlush(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Turns 'auto-flush' on or off.
- setAutoFlush(boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Deprecated.
in 0.96. When called with setAutoFlush(false), this function also
set clearBufferOnFail to true, which is unexpected but kept for historical reasons.
Replace it with setAutoFlush(false, false) if this is exactly what you want, or by
HTableInterface.setAutoFlushTo(boolean)
for all other cases.
- setAutoFlush(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Turns 'auto-flush' on or off.
- setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- setAutoFlush(boolean, boolean) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- setAutoFlushTo(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Set the autoFlush behavior, without changing the value of clearBufferOnFail
- setAutoFlushTo(boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Set the autoFlush behavior, without changing the value of clearBufferOnFail
- setAutoFlushTo(boolean) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- setBalancerRunning(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Turn the load balancer on or off.
- setBatch(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum number of values to return for each call to next()
- setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setBlocksize(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setBody(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
Set whether blocks should be cached for this Get.
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether blocks should be cached for this Scan.
- setCacheBloomsOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the number of rows for caching that will be passed to scanners.
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Sets the visibility expression associated with cells in this Mutation.
- setChance(float) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Set the chance that a row is included.
- setCharset(Charset) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Specifies the
Charset
to use to convert the row key to a String.
- setCheckExistenceOnly(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
- setCheckHdfs(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setCipher(Cipher) - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- setClosestRowBefore(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
- setCluster(Cluster) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Marks that the clusters with the given clusterIds have consumed the mutation
- setCode(int) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Compression types supported in hbase.
- setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Setting the table compaction enable flag.
- setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Compression types supported in hbase.
- setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set whether the tags should be compressed along with DataBlockEncoding.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set data block encoding algorithm used in block cache.
- setDefaultClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- setDeferredLogFlush(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setDisplayFullReport() - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Display the full report from fsck.
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the durability for this mutation
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setEncodeOnDisk(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
- setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set the raw crypto key attribute for the family
- setEncryptionType(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set the encryption algorithm for use with this family
- setEndKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
- setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setExists(Boolean) - Method in class org.apache.hadoop.hbase.client.Result
-
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for setting the put's familyMap
- setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - Method in class org.apache.hadoop.hbase.client.Scan
-
Setting the familyMap
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Get
-
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Query
-
Apply the specified server-side filter when performing the Query.
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Set whether entire row should be filtered if column is not found.
- setFirst(T1) - Method in class org.apache.hadoop.hbase.util.Pair
-
Replace the first element of the pair.
- setFixAssignments(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Fix inconsistencies found by fsck.
- setFixEmptyMetaCells(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixHdfsHoles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixHdfsOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixHdfsOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixMeta(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixReferenceFiles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixSplitParents(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixTableLocks(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Set table locks fix mode.
- setFixTableOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixVersionFile(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFoundKV(boolean) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- setHeaders(Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- setHFileCorruptionChecker(HFileCorruptionChecker) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Deprecated.
Allows subclasses to set the
HTable
.
- setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
- setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
- setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to set the
HTable
.
- setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Sets the HBase table.
- setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Sets the HBase table.
- setId(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
This method allows you to set an identifier on an operation.
- setIgnorePreCheckPermission(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setInput(JobConf, String, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(Job, String, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Deprecated.
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Query
-
Set the isolation level for this query.
- setIv(byte[]) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Set the initialization vector
- setIv(byte[]) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Set the initialization vector
- setKeepDeletedCells(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- setKey(Key) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Set the secret key
- setKey(Key) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Set the secret key
- setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Set whether only the latest version of the column value should be compared.
- setLength(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Update the length of this range.
- setLength(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- setLength(int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- setLength(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Update the length of this range.
- setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the value indicating whether loading CFs on demand should be allowed (cluster
default is false).
- setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Sets the maximum size upto which a region can grow to after which a region
split is triggered.
- setMaxMerge(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setMaxOverlapsToSideline(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setMaxResultSize(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum result size.
- setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Set the maximum number of values to return per row per Column Family
- setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum number of values to return per row per Column Family
- setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
-
Get all available versions.
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Get up to the specified number of versions of each column.
- setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get all available versions.
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get up to the specified number of versions of each column.
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Represents the maximum size of the memstore after which the contents of the
memstore are flushed to the filesystem.
- setMetaRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used to denote if the current table represents
-ROOT-
or hbase:meta
region.
- setMinVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setName(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setName(TableName) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setNumMapTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
Sets the number of map tasks for the given job configuration to the
number of regions the given table has.
- setNumReduceTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
Sets the number of reduce tasks for the given job configuration to the
number of regions the given table has.
- setNumReduceTasks(String, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets the number of reduce tasks for the given job configuration to the
number of regions the given table has.
- setOffline(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
The parent of a region split is offline while split daughters hold
references to the parent.
- setOffset(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Update the beginning of this range.
- setOffset(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- setOffset(int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- setOffset(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Update the beginning of this range.
- setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
-
- setOwner(User) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setOwnerString(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Set the replicable table-cf config of the specified peer
- setPosition(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Update the position
index.
- setPosition(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setRaw(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Enable/disable "raw" mode for this scan.
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Setting the table as read only sets all the columns in the table as read
only.
- setRegionCachePrefetch(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Enable or disable region cache prefetch for the table.
- setRegionCachePrefetch(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- setRegionCachePrefetch(byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Enable or disable region cache prefetch for the table.
- setRegionCachePrefetch(TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- setRegionCachePrefetch(Configuration, byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Enable or disable region cache prefetch for the table.
- setRegionCachePrefetch(Configuration, TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- setRegionFilter(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
sets the region by which output will be filtered
- setRetCode(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Append
-
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether this scan is a reversed one
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.Filter
-
alter the reversed scan flag
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- setRootRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used to denote if the current table represents
-ROOT-
region.
- setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Deprecated.
Allows subclasses to set the
Filter
to be used.
- setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
- setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
- setRowFilter(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
sets the region by which output will be filtered
- setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Set offset for the row per Column Family.
- setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set offset for the row per Column Family.
- setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Sets the scan defining the actual details like columns etc.
- setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Sets the scan defining the actual details like columns etc.
- setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Sets the scan defining the actual details like columns etc.
- setScannerCaching(int) - Method in class org.apache.hadoop.hbase.client.HTable
-
- setScannerCaching(JobConf, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
Sets the number of rows to return and cache with each scanner iteration.
- setScannerCaching(Job, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets the number of rows to return and cache with each scanner iteration.
- setScans(List<Scan>) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to set the list of
Scan
objects.
- setScope(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setSecond(T2) - Method in class org.apache.hadoop.hbase.util.Pair
-
Replace the second element of the pair.
- setSequenceFilter(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
sets the region by which output will be filtered
- setServerSideHConnectionRetries(Configuration, String, Log) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Set the number of retries to use serverside when trying to communicate
with another server over
HConnection
.
- setSidelineBigOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setSidelineDir(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setSmall(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether this scan is a small scan
- setSplit(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- setStartKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the start row of the scan.
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the stop row.
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Deprecated.
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- setTickTime(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- setTimeLag(long) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
We are interested in only those tables that have not changed their state in
hbase:meta during the last few seconds specified by hbase.admin.fsck.timelag
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Get
-
Get versions of columns only within the specified timestamp range,
[minStamp, maxStamp).
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Increment
-
Sets the TimeRange to be used on the Get for this increment.
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get versions of columns only within the specified timestamp range,
[minStamp, maxStamp).
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Set the timestamp of the delete.
- setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Get
-
Get versions of columns with the specified timestamp.
- setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get versions of columns with the specified timestamp.
- setTimeToLive(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setup(Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
Handles initializing this class with objects specific to it (i.e., the parser).
- setup(Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Handles initializing this class with objects specific to it (i.e., the parser).
- setup(Mapper<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
Handles initializing this class with objects specific to it (i.e., the parser).
- setupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setValue(ImmutableBytesWritable, ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.HTable
-
Sets the size of the buffer in bytes.
- setWriteBufferSize(long) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Sets the size of the buffer in bytes.
- setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- shallowCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Create a new ByteRange
that points at this range's byte[].
- shallowCopy() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- shallowCopySubRange(int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Create a new ByteRange
that points at this range's byte[].
- shallowCopySubRange(int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- shouldCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCompressTags() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldFixVersionFile() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- shouldIgnorePreCheckPermission() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- shouldPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldSidelineBigOverlaps() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- shutdown() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Shuts down the HBase cluster
- shutdown() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Shut down the mini HBase cluster
- shutdown() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Shut down the client.
- shutdown() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- SimpleByteRange - Class in org.apache.hadoop.hbase.util
-
- SimpleByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
Create a new ByteRange
lacking a backing array and with an
undefined viewport.
- SimpleByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
Create a new ByteRange
over a new backing array of size
capacity
.
- SimpleByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
Create a new ByteRange
over the provided bytes
.
- SimpleByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
Create a new ByteRange
over the provided bytes
.
- SimplePositionedByteRange - Class in org.apache.hadoop.hbase.util
-
- SimplePositionedByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new PositionedByteRange
lacking a backing array and with
an undefined viewport.
- SimplePositionedByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new PositionedByteRange
over a new backing array of
size capacity
.
- SimplePositionedByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new PositionedByteRange
over the provided bytes
.
- SimplePositionedByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new PositionedByteRange
over the provided bytes
.
- SimpleTotalOrderPartitioner<VALUE> - Class in org.apache.hadoop.hbase.mapreduce
-
A partitioner that takes start and end keys and uses bigdecimal to figure
which reduce a key belongs to.
- SimpleTotalOrderPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- SINGLE_QUOTE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for a single quote
- SingleColumnValueExcludeFilter - Class in org.apache.hadoop.hbase.filter
-
A
Filter
that checks a single column value, but does not emit the
tested column.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for protobuf deserialization only.
- SingleColumnValueFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter cells based on value.
- SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for protobuf deserialization only.
- size() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Number of KeyValues carried by this Mutation.
- size() - Method in class org.apache.hadoop.hbase.client.Result
-
- size() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- SIZEOF_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of boolean in bytes
- SIZEOF_BYTE - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of byte in bytes
- SIZEOF_CHAR - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of char in bytes
- SIZEOF_DOUBLE - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of double in bytes
- SIZEOF_FLOAT - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of float in bytes
- SIZEOF_INT - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of int in bytes
- SIZEOF_LONG - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of long in bytes
- SIZEOF_SHORT - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of short in bytes
- skip(PositionedByteRange) - Method in interface org.apache.hadoop.hbase.types.DataType
-
Skip src
's position forward over one encoded value.
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawByte
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawLong
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawShort
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawString
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
-
- skip() - Method in class org.apache.hadoop.hbase.types.StructIterator
-
Bypass the next encoded value.
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
Skip src
's position forward over one encoded value.
- skip(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Increment position in buffer.
- skip(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Skip buff
's position forward over one encoded value.
- SKIP_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
SKIP Array
- SKIP_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- SKIP_LINES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- SkipFilter - Class in org.apache.hadoop.hbase.filter
-
A wrapper filter that filters an entire row if any of the Cell checks do
not pass.
- SkipFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.SkipFilter
-
- snapshot(String, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Take a snapshot for the given table.
- snapshot(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(byte[], byte[], HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create snapshot for the given table of given flush type.
- snapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
public void snapshot(final String snapshotName,
Create a timestamp consistent snapshot for the given table.
- snapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(String, TableName, HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create typed snapshot of the table.
- snapshot(String, String, HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(String, byte[], HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Take a snapshot and wait for the server to complete that snapshot (blocking).
- SNAPSHOT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Name of the directory to store all snapshots.
- SnapshotCreationException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot could not be created due to a server-side error when
taking the snapshot.
- SnapshotCreationException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Used internally by the RPC engine to pass the exception back to the client.
- SnapshotCreationException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Failure to create the specified snapshot
- SnapshotCreationException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Failure to create the specified snapshot due to an external cause
- SnapshotDoesNotExistException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when the server is looking for a snapshot but can't find the snapshot on the filesystem
- SnapshotDoesNotExistException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
-
- SnapshotDoesNotExistException(HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
-
- SnapshotExistsException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot exists but should not
- SnapshotExistsException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
-
Failure due to the snapshot already existing
- SnapshotInfo - Class in org.apache.hadoop.hbase.snapshot
-
Tool for dumping snapshot information.
- SnapshotInfo() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- SOCKET_RETRY_WAIT_MS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The delay when re-trying a socket operation in a loop (HBASE-4712)
- sortedPrefixes - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- split(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Split a table or an individual region.
- split(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Split a table or an individual region.
- split(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Split a table or an individual region.
- split(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Split passed range.
- split(byte[], byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Split passed range.
- SPLIT_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used to construct the name of the splitlog directory for a region server
- SPLIT_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
- SPLITA_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The lower-half split region column qualifier
- SPLITB_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The upper-half split region column qualifier
- splitStoreFile(LoadIncrementalHFiles.LoadQueueItem, HTable, byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- src - Variable in class org.apache.hadoop.hbase.types.StructIterator
-
- stampSet - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- START - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
Deprecated.
- START_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
- STARTCODE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The startcode column qualifier
- startsWith(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Return true if the byte array on the right is a prefix of the byte
array on the left.
- startup() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Start the cluster.
- startup(File) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- startup(File, int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- STATE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The state column qualifier
- STATUS_MULTICAST_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
IP to use for the multicast status messages between the master and the clients.
- STATUS_MULTICAST_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The address to use for binding the local socket for receiving multicast.
- STATUS_MULTICAST_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
The port to use for the multicast messages.
- STATUS_PUBLISHED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Setting to activate, or not, the publication of the status by the master.
- STATUS_PUBLISHED_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- stopMaster() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Shuts down the current HBase master only.
- StoppedRpcClientException - Exception in org.apache.hadoop.hbase.ipc
-
- StoppedRpcClientException() - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
-
- StoppedRpcClientException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
-
- stopRegionServer(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Stop the designated regionserver
- store - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- Struct - Class in org.apache.hadoop.hbase.types
-
Struct
is a simple
DataType
for implementing "compound
rowkey" and "compound qualifier" schema design strategies.
- Struct(DataType[]) - Constructor for class org.apache.hadoop.hbase.types.Struct
-
Create a new Struct
instance defined as the sequence of
HDataType
s in memberTypes
.
- StructBuilder - Class in org.apache.hadoop.hbase.types
-
A helper for building
Struct
instances.
- StructBuilder() - Constructor for class org.apache.hadoop.hbase.types.StructBuilder
-
Create an empty StructBuilder
.
- StructIterator - Class in org.apache.hadoop.hbase.types
-
An
Iterator
over encoded
Struct
members.
- StructIterator(PositionedByteRange, DataType[]) - Constructor for class org.apache.hadoop.hbase.types.StructIterator
-
Construct StructIterator
over the values encoded in src
using the specified types
definition.
- SubstringComparator - Class in org.apache.hadoop.hbase.filter
-
This comparator is for use with SingleColumnValueFilter, for filtering based on
the value of a given column.
- SubstringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.SubstringComparator
-
Constructor
- substringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
SubstringType byte array
- SYSTEM_NAMESPACE - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- SYSTEM_NAMESPACE_NAME - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
System namespace name.
- SYSTEM_NAMESPACE_NAME_STR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- TAB - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for tab
- TABLE_MULTIPLEXER_FLUSH_PERIOD_MS - Static variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- TABLE_MULTIPLEXER_INIT_THREADS - Static variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- TABLE_MULTIPLEXER_MAX_RETRIES_IN_QUEUE - Static variable in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- TABLE_NAME - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
-
- tableExists(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- tableExists(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- tableExists(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- TableExistsException - Exception in org.apache.hadoop.hbase
-
Thrown when a table exists but should not
- TableExistsException() - Constructor for exception org.apache.hadoop.hbase.TableExistsException
-
default constructor
- TableExistsException(String) - Constructor for exception org.apache.hadoop.hbase.TableExistsException
-
Constructor
- TableExistsException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableExistsException
-
- TableInfoMissingException - Exception in org.apache.hadoop.hbase
-
Failed to find .tableinfo file under table dir
- TableInfoMissingException() - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
-
- TableInfoMissingException(String) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
-
- TableInfoMissingException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
-
- TableInfoMissingException(Throwable) - Constructor for exception org.apache.hadoop.hbase.TableInfoMissingException
-
- TableInputFormat - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormat
-
Deprecated.
- TableInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Convert HBase tabular data into a format that is consumable by Map/Reduce.
- TableInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
- TableInputFormatBase - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Deprecated.
- TableInputFormatBase - Class in org.apache.hadoop.hbase.mapreduce
-
- TableInputFormatBase() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- TableMap<K extends org.apache.hadoop.io.WritableComparable<? super K>,V> - Interface in org.apache.hadoop.hbase.mapred
-
Deprecated.
- TableMapper<KEYOUT,VALUEOUT> - Class in org.apache.hadoop.hbase.mapreduce
-
Extends the base Mapper
class to add the required input key
and value classes.
- TableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableMapper
-
- TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
- TableMapReduceUtil - Class in org.apache.hadoop.hbase.mapreduce
-
- TableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
- TableName - Class in org.apache.hadoop.hbase
-
Immutable POJO class for representing a table name.
- TableNotDisabledException - Exception in org.apache.hadoop.hbase
-
Thrown if a table should be offline but is not
- TableNotDisabledException() - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
-
default constructor
- TableNotDisabledException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
-
Constructor
- TableNotDisabledException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
-
- TableNotDisabledException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotDisabledException
-
- TableNotEnabledException - Exception in org.apache.hadoop.hbase
-
Thrown if a table should be enabled but is not
- TableNotEnabledException() - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
-
default constructor
- TableNotEnabledException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
-
Constructor
- TableNotEnabledException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
-
- TableNotEnabledException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotEnabledException
-
- TableNotFoundException - Exception in org.apache.hadoop.hbase
-
Thrown when a table can not be located
- TableNotFoundException() - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
-
default constructor
- TableNotFoundException(String) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
-
- TableNotFoundException(byte[]) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
-
- TableNotFoundException(TableName) - Constructor for exception org.apache.hadoop.hbase.TableNotFoundException
-
- TableOutputCommitter - Class in org.apache.hadoop.hbase.mapreduce
-
Small committer class that does not do anything.
- TableOutputCommitter() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- TableOutputFormat - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
Deprecated.
- TableOutputFormat<KEY> - Class in org.apache.hadoop.hbase.mapreduce
-
Convert Map/Reduce output and write it to an HBase table.
- TableOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
- TablePartiallyOpenException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown if a table should be online/offline but is partially open
- TablePartiallyOpenException() - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
-
- TablePartiallyOpenException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
-
- TablePartiallyOpenException(TableName) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
-
- TablePartiallyOpenException(byte[]) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
-
- TableRecordReader - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Deprecated.
- TableRecordReader - Class in org.apache.hadoop.hbase.mapreduce
-
Iterate over an HBase table data, return (ImmutableBytesWritable, Result)
pairs.
- TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
- TableRecordReaderImpl - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- TableRecordReaderImpl() - Constructor for class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Deprecated.
- TableRecordReaderImpl - Class in org.apache.hadoop.hbase.mapreduce
-
Iterate over an HBase table data, return (ImmutableBytesWritable, Result)
pairs.
- TableRecordReaderImpl() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
- TableReduce<K extends org.apache.hadoop.io.WritableComparable,V> - Interface in org.apache.hadoop.hbase.mapred
-
Deprecated.
- TableReducer<KEYIN,VALUEIN,KEYOUT> - Class in org.apache.hadoop.hbase.mapreduce
-
Extends the basic Reducer
class to add the required key and
value input/output classes.
- TableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableReducer
-
- TableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapred
-
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
- TableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
- TableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
TableSnapshotInputFormat allows a MapReduce job to run over a table snapshot.
- TableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
- TableSnapshotScanner - Class in org.apache.hadoop.hbase.client
-
A Scanner which performs a scan over snapshot files.
- TableSnapshotScanner(Configuration, Path, String, Scan) - Constructor for class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
Creates a TableSnapshotScanner.
- TableSnapshotScanner(Configuration, Path, Path, String, Scan) - Constructor for class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
Creates a TableSnapshotScanner.
- TableSplit - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- TableSplit() - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
default constructor
- TableSplit(TableName, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
Constructor
- TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
- TableSplit - Class in org.apache.hadoop.hbase.mapreduce
-
A table split corresponds to a key range (low, high) and an optional scanner.
- TableSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Default constructor.
- TableSplit(byte[], Scan, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
- TableSplit(TableName, Scan, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Creates a new instance while assigning all variables.
- TableSplit(TableName, Scan, byte[], byte[], String, long) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Creates a new instance while assigning all variables.
- TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
- TableSplit(TableName, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Creates a new instance without a scanner.
- TableSplit(TableName, byte[], byte[], String, long) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Creates a new instance without a scanner.
- tagsIterator(byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Util method to iterate through the tags
- tail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- takeSnapshotAsync(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Take a snapshot without waiting for the server to complete that snapshot (asynchronous)
- term - Variable in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- TerminatedWrapper<T> - Class in org.apache.hadoop.hbase.types
-
Wraps an existing DataType
implementation as a terminated
version of itself.
- TerminatedWrapper(DataType<T>, byte[]) - Constructor for class org.apache.hadoop.hbase.types.TerminatedWrapper
-
Create a terminated version of the wrapped
.
- TerminatedWrapper(DataType<T>, String) - Constructor for class org.apache.hadoop.hbase.types.TerminatedWrapper
-
Create a terminated version of the wrapped
.
- terminatorPosition(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
Return the position at which term
begins within src
,
or -1
if term
is not found.
- testCompression(String) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
-
- testCompression(Compression.Algorithm) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
-
- TextSortReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Emits Sorted KeyValues.
- TextSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- THREAD_WAKE_FREQUENCY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for how often threads should wake up
- TimeoutException - Exception in org.apache.hadoop.hbase.errorhandling
-
Exception for timeout of a task.
- TimeoutException(String, long, long, long) - Constructor for exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
Exception indicating that an operation attempt has timed out
- TimeRange - Class in org.apache.hadoop.hbase.io
-
Represents an interval of version timestamps.
- TimeRange() - Constructor for class org.apache.hadoop.hbase.io.TimeRange
-
Default constructor.
- TimeRange(long) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
-
Represents interval [minStamp, Long.MAX_VALUE)
- TimeRange(byte[]) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
-
Represents interval [minStamp, Long.MAX_VALUE)
- TimeRange(long, long) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
-
Represents interval [minStamp, maxStamp)
- TimeRange(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.io.TimeRange
-
Represents interval [minStamp, maxStamp)
- TIMESTAMP_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- TimestampsFilter - Class in org.apache.hadoop.hbase.filter
-
Filter that returns only cells whose timestamp (version) is
in the specified list of timestamps (versions).
- TimestampsFilter(List<Long>) - Constructor for class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Constructor for filter that retains only those
cells whose timestamp (version) is in the specified
list of timestamps.
- TNAME - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- toArray(List<byte[]>) - Static method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- toBigDecimal(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a BigDecimal
- toBigDecimal(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a BigDecimal value
- toBinaryFromHex(byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Takes a ASCII digit in the range A-F0-9 and returns
the corresponding integer/ordinal value.
- toBoolean(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- toByte() - Method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.Filter
-
TODO: JAVADOC
Concrete implementers can signal a failure condition in their code by throwing an
IOException
.
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.RowFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.ValueFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- toByteArray() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- toByteArray() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- toByteArray() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- toByteArray(int, int) - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- toByteArrays(String[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- toByteArrays(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- toByteArrays(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- toBytes() - Method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
- toBytes() - Method in class org.apache.hadoop.hbase.TableName
-
- toBytes(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy the bytes from position to limit into a new byte[] of the exact length and sets the
position and limit back to their original values (though not thread safe).
- toBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns a new byte array, copied from the given buf
,
from the index 0 (inclusive) to the limit (exclusive),
regardless of the current position.
- toBytes(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a string to a UTF-8 byte array.
- toBytes(boolean) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert a boolean to a byte array.
- toBytes(long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert a long value to a byte array using big-endian.
- toBytes(float) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- toBytes(double) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Serialize a double as the IEEE 754 double format output.
- toBytes(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert an int value to a byte array.
- toBytes(short) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- toBytes(BigDecimal) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert a BigDecimal value to a byte array
- toBytesBinary(String) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- toDelimitedByteArray() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Use this instead of
HRegionInfo.toByteArray()
when writing to a stream and you want to use
the pb mergeDelimitedFrom (w/o the delimiter, pb reads to EOF which may not be what you want).
- toDelimitedByteArray(HRegionInfo...) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Serializes given HRegionInfo's as a byte array.
- toDouble(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- toDouble(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- toFloat(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Presumes float encoded as IEEE 754 floating-point "single format"
- toFloat(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Presumes float encoded as IEEE 754 floating-point "single format"
- toHex(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Convert a byte array into a hex string
- toInt(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to an int value
- toInt(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to an int value
- toInt(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to an int value
- toIntUnsafe(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to an int value (Unsafe version)
- toJSON(int) - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a JSON object for fingerprint and details exposure in a
parseable format.
- toJSON() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a JSON object sufficient for description of a query
in a debugging or logging context.
- toLong(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a long value.
- toLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a long value.
- toLong(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a long value.
- toLongUnsafe(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to an long value (Unsafe version)
- toMap(int) - Method in class org.apache.hadoop.hbase.client.Delete
-
- toMap(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Compile the details beyond the scope of getFingerprint (row, columns,
timestamps, etc.) into a Map along with the fingerprinted information.
- toMap(int) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Compile the details beyond the scope of getFingerprint (row, columns,
timestamps, etc.) into a Map along with the fingerprinted information.
- toMap(int) - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a Map containing a summary of the details of a query
beyond the scope of the fingerprint (i.e.
- toMap() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a Map containing a full summary of a query.
- toMap(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Compile the details beyond the scope of getFingerprint (row, columns,
timestamps, etc.) into a Map along with the fingerprinted information.
- toShort(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a short value
- toShort(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a short value
- toShort(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to a short value
- toShortString() - Method in class org.apache.hadoop.hbase.ServerName
-
- toShortUnsafe(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts a byte array to an short value (Unsafe version)
- toString() - Method in class org.apache.hadoop.hbase.client.HTable
-
- toString() - Method in class org.apache.hadoop.hbase.client.Increment
-
- toString(int) - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a string representation of this Operation.
- toString() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a string representation of this Operation.
- toString() - Method in class org.apache.hadoop.hbase.client.Result
-
- toString() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- toString() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- toString(int) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- toString() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- toString(int) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- toString(int) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- toString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- toString() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- toString() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- toString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- toString() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- toString() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- toString() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
- toString() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
- toString() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the details about this instance as a string.
- toString() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- toString() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- toString() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- toString() - Method in class org.apache.hadoop.hbase.ServerName
-
- toString() - Method in class org.apache.hadoop.hbase.TableName
-
- toString(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- toString(byte[], String, byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Joins two byte arrays together using a separator.
- toString(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
This method will convert utf8 encoded bytes into a string.
- toString() - Method in class org.apache.hadoop.hbase.util.Pair
-
- toString() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
- toString() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- toStringBinary(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write a printable representation of a byte array.
- toStringBinary(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Converts the given byte buffer to a printable representation,
from the index 0 (inclusive) to the limit (exclusive),
regardless of the current position.
- toStringBinary(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Write a printable representation of a byte array.
- toStringCustomizedValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- toStringCustomizedValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- toStruct() - Method in class org.apache.hadoop.hbase.types.StructBuilder
-
Retrieve the
Struct
represented by
this
.
- transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Deprecated.
- transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Deprecated.
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Give the filter a chance to transform the passed KeyValue.
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- transformCell(Cell) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- tryAtomicRegionLoad(HConnection, byte[], byte[], Collection<LoadIncrementalHFiles.LoadQueueItem>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- tryAtomicRegionLoad(HConnection, TableName, byte[], Collection<LoadIncrementalHFiles.LoadQueueItem>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
Attempts to do an atomic load of many hfiles into a region.
- ts - Variable in class org.apache.hadoop.hbase.client.Mutation
-
- ts - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Timestamp for all inserted rows
- TsvImporterMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Write table content out to files in hdfs.
- TsvImporterMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- TsvImporterTextMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Write table content out to map output files.
- TsvImporterTextMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- typeA - Variable in class org.apache.hadoop.hbase.types.Union2
-
- typeB - Variable in class org.apache.hadoop.hbase.types.Union2
-
- typeC - Variable in class org.apache.hadoop.hbase.types.Union3
-
- typeD - Variable in class org.apache.hadoop.hbase.types.Union4
-
- types - Variable in class org.apache.hadoop.hbase.types.StructIterator
-