- A - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'A'
- abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.Abortable
-
Abort the server or client.
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- abort(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- abort(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
Receive a notification and propagate it to the local coordinator
- abort(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
Pass along the found abort notification to the listener
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Cause the server to exit without closing the regions it is serving, the log
it is using and without notifying the master.
- abort(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- ABORT_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- Abortable - Interface in org.apache.hadoop.hbase
-
Interface to support the aborting of a given server or client.
- abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Used to abort if a fatal error occurs
- abortCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Abort a cache flush.
- abortProcedure(String, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Abort the procedure with the given name
- abortRequested - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- abortServer(String, Server, CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- abortServer(CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- abortServer(CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- abortServer(CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- abortZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- AbstractClientScanner - Class in org.apache.hadoop.hbase.client
-
Helper class for custom client scanners.
- AbstractClientScanner() - Constructor for class org.apache.hadoop.hbase.client.AbstractClientScanner
-
- AbstractHBaseTool - Class in org.apache.hadoop.hbase.util
-
Common base class used for HBase command-line tools.
- AbstractHBaseTool() - Constructor for class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- AbstractHFileReader - Class in org.apache.hadoop.hbase.io.hfile
-
Common functionality needed by all versions of
HFile
readers.
- AbstractHFileReader(Path, FixedFileTrailer, FSDataInputStream, long, boolean, CacheConfig) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- AbstractHFileReader(Path, FixedFileTrailer, FSDataInputStream, FSDataInputStream, long, boolean, CacheConfig, HFileSystem) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- AbstractHFileReader.BlockIndexNotLoadedException - Exception in org.apache.hadoop.hbase.io.hfile
-
- AbstractHFileReader.BlockIndexNotLoadedException() - Constructor for exception org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.BlockIndexNotLoadedException
-
- AbstractHFileReader.NotSeekedException - Exception in org.apache.hadoop.hbase.io.hfile
-
An exception thrown when an operation requiring a scanner to be seeked
is invoked on a scanner that is not seeked.
- AbstractHFileReader.NotSeekedException() - Constructor for exception org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.NotSeekedException
-
- AbstractHFileReader.Scanner - Class in org.apache.hadoop.hbase.io.hfile
-
- AbstractHFileReader.Scanner(HFile.Reader, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- AbstractHFileWriter - Class in org.apache.hadoop.hbase.io.hfile
-
Common functionality needed by all versions of
HFile
writers.
- AbstractHFileWriter(CacheConfig, FSDataOutputStream, Path, int, Compression.Algorithm, HFileDataBlockEncoder, KeyValue.KeyComparator) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.DirFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
-
- ACCEPT_POLICY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
The strategy for handling new accepted connections.
- ACCEPT_QUEUE_SIZE_PER_THREAD_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Maximum number of accepted elements per selector
- access(long) - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
-
Block has been accessed.
- AccessController - Class in org.apache.hadoop.hbase.security.access
-
Provides basic authorization checks for data access and administrative
operations.
- AccessController() - Constructor for class org.apache.hadoop.hbase.security.access.AccessController
-
- AccessControllerProtocol - Interface in org.apache.hadoop.hbase.security.access
-
A custom protocol defined for maintaining and querying access control lists.
- AccessControlLists - Class in org.apache.hadoop.hbase.security.access
-
Maintains lists of permission grants to users and groups to allow for
authorization checks by
AccessController
.
- AccessControlLists() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- AccessDeniedException - Exception in org.apache.hadoop.hbase.security
-
Exception thrown by access-related methods.
- AccessDeniedException() - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- AccessDeniedException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- AccessDeniedException(String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- accumulateStoreMetric(Map<String, MutableDouble>, SchemaMetrics.StoreMetricType, double) - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
Used to accumulate store metrics across multiple regions in a region
server.
- ACL_GLOBAL_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- ACL_KEY_DELIMITER - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Delimiter to separate user, column family, and qualifier in
_acl_ table info: column keys
- ACL_LIST_FAMILY - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- ACL_LIST_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Column family used to store ACL grants
- ACL_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- ACL_TABLE_NAME_STR - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Internal storage table for access control lists
- ACL_TABLEDESC - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Table descriptor for ACL internal table
- AClusterStatus - Class in org.apache.hadoop.hbase.avro.generated
-
- AClusterStatus() - Constructor for class org.apache.hadoop.hbase.avro.generated.AClusterStatus
-
- AColumn - Class in org.apache.hadoop.hbase.avro.generated
-
- AColumn() - Constructor for class org.apache.hadoop.hbase.avro.generated.AColumn
-
- AColumnValue - Class in org.apache.hadoop.hbase.avro.generated
-
- AColumnValue() - Constructor for class org.apache.hadoop.hbase.avro.generated.AColumnValue
-
- ACompressionAlgorithm - Enum in org.apache.hadoop.hbase.avro.generated
-
- acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
The implementation of this method should gather and hold required resources (locks, disk
space, etc) to satisfy the Procedures barrier condition.
- acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- acquireBarrier() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
- ACQUIRED_BARRIER_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- acquiredZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- Action<R> - Class in org.apache.hadoop.hbase.client
-
- Action() - Constructor for class org.apache.hadoop.hbase.client.Action
-
- Action(byte[], Row, int) - Constructor for class org.apache.hadoop.hbase.client.Action
-
Deprecated.
- Action(Row, int) - Constructor for class org.apache.hadoop.hbase.client.Action
-
- ACTION_BY_CODE - Static variable in class org.apache.hadoop.hbase.security.access.Permission
-
- actions - Variable in class org.apache.hadoop.hbase.client.MultiAction
-
- actions - Variable in class org.apache.hadoop.hbase.security.access.Permission
-
- ActiveMasterManager - Class in org.apache.hadoop.hbase.master
-
Handles everything on master-side related to master election.
- activeRpcCount - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- actualErrorRate() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Computes the error rate for this Bloom filter, taking into account the
actual number of hash functions and keys inserted.
- actualErrorRate(long, long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Computes the actual error rate for the given number of elements, number
of bits, and number of hash functions.
- add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
-
Add the specified column and value to this Append operation.
- add(KeyValue) - Method in class org.apache.hadoop.hbase.client.Append
-
Add the specified
KeyValue
to this operation.
- add(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- add(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- add(byte[], Action<R>) - Method in class org.apache.hadoop.hbase.client.MultiAction
-
Add an Action to this container based on it's regionName.
- add(byte[], Put) - Method in class org.apache.hadoop.hbase.client.MultiPut
-
Deprecated.
- add(byte[], Pair<Integer, Object>) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
Add the pair to the container, grouped by the regionName
- add(byte[], int, Object) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified column and value to this Put operation.
- add(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified column and value, with the specified timestamp as
its version to this Put operation.
- add(KeyValue) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified KeyValue to this Put operation.
- add(Put) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Add a
Put
operation to the list of mutations
- add(Delete) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Add a
Delete
operation to the list of mutations
- add(HTableDescriptor, Class<? extends Constraint>...) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Add configuration-less constraints to the table.
- add(HTableDescriptor, Pair<Class<? extends Constraint>, Configuration>...) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Add constraints and their associated configurations to the table.
- add(HTableDescriptor, Class<? extends Constraint>, Configuration) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Add a
Constraint
to the table with the given configuration
- add(S, S) - Method in interface org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- add(HDFSBlocksDistribution) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
This will add the distribution from input to this object
- add(CachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlockQueue
-
Attempt to add the specified cached block to this queue.
- add(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- add(String) - Method in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
-
Append the given message to this buffer, automatically evicting
older messages until the desired memory limit is achieved.
- add(byte[], int, int, long, byte) - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
-
Add the specified KeyValue to the list of deletes to check against for
this row operation.
- add(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- add(byte[], int, int, long, byte) - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
Add the specified KeyValue to the list of deletes to check against for
this row operation.
- add(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
Adds a value to the memstore
- add(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- add(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Add a node to the cluster
- add(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Add a node to the cluster
- add(TableRegionModel) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
Add a region model to the list
- add(TableModel) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
Add the table name model to the list
- add(HTableDescriptor) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Add or update descriptor
- add(Runnable) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- add(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Add the specified binary to the bloom filter.
- add(byte[]) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- add(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- add(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- add(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- add(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
Adds a Bloom filter key.
- add(HTableDescriptor) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- add(R) - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
Adds an edge to the split calculator
- add(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- addAll(Collection<? extends ServerName>) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- addAll(Collection<? extends KeyValue>) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- addAll(Collection<? extends Runnable>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- addAll(Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- addAllAttrs(Iterable<? extends ColumnSchemaMessage.ColumnSchema.Attribute>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- addAllAttrs(Iterable<? extends TableSchemaMessage.TableSchema.Attribute>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addAllColumns(Iterable<? extends ByteString>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- addAllColumns(Iterable<? extends ColumnSchemaMessage.ColumnSchema>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addAllDeadNodes(Iterable<String>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- addAllLiveNodes(Iterable<? extends StorageClusterStatusMessage.StorageClusterStatus.Node>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- addAllName(Iterable<String>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- addAllRegions(Iterable<? extends StorageClusterStatusMessage.StorageClusterStatus.Region>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- addAllRegions(Iterable<? extends TableInfoMessage.TableInfo.Region>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- addAllRows(Iterable<? extends CellSetMessage.CellSet.Row>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- addAllTrace(Iterable<? extends ErrorHandlingProtos.StackTraceElementMessage>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- addAllValues(Iterable<? extends CellMessage.Cell>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- addAndGetGlobalMemstoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Increase the size of mem store in this region and the size of global mem
store
- addAndGetGlobalMemstoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- addAndGetRegionReplayEditsSize(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Add memStoreSize to replayEditsPerRegion.
- addAttribute(String, Object) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
Add an attribute to the column family schema
- addAttribute(String, Object) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Add an attribute to the table descriptor
- addAttrs(ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- addAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- addAttrs(ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- addAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- addAttrs(TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addAttrs(int, TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addAttrs(TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addAttrs(int, TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addAttrsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- addAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- addAttrsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addCall(HBaseClient.Call) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
Add a call to this connection's call queue and notify
a listener; synchronized.
- addCell(CellModel) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
Adds a cell to the list of cells for this row
- addClusterId(UUID) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
Marks that the cluster with the given clusterId has consumed the change.
- addClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
Marks that the clusters with the given clusterIds have consumed the change.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Get
-
Get the column from the specific family with the specified qualifier.
- addColumn(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Add a column to an existing table.
- addColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Add a column to an existing table.
- addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Increment
-
Increment the column from the specific family with the specified qualifier
by the specified amount.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the column from the specified family with the specified qualifier.
- addColumn(byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Adds a column to the specified table
- addColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- addColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Add column to a table
- addColumn(byte[], HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Add a new column to an existing table
- addColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Add a column to the column set
- addColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- addColumnFamily(ColumnSchemaModel) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Add a column family to the table descriptor
- addColumns(Scan, byte[][]) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Adds an array of columns specified using old format, family:qualifier.
- addColumns(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- addColumns(ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addColumns(int, ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addColumns(ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addColumns(int, ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addColumnsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addColumnsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- addCompaction(long, long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- addCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Add a table coprocessor to this table.
- addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Add a table coprocessor to this table.
- addDaughter(CatalogTracker, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
-
- addDeadNode(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Add a dead node to the cluster representation.
- addDeadNodes(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- addDeleteFamilyBloomFilter(BloomFilterWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Store delete family Bloom filter in the file, which is only supported in
HFile V2.
- addDeleteFamilyBloomFilter(BloomFilterWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV1
-
- addDeleteFamilyBloomFilter(BloomFilterWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- addDeleteMarker(KeyValue) - Method in class org.apache.hadoop.hbase.client.Delete
-
Advanced use only.
- addDependencyJars(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Deprecated.
- addDependencyJars(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Add the HBase dependency jars as well as jars for any of the configured
job classes to the job configuration, so that JobClient will ship them
to the cluster and add them to the DistributedCache.
- addDependencyJars(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Add the jars containing the given classes to the job's configuration
such that JobClient will ship them to the cluster and add them to
the DistributedCache.
- addEntry(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Add one index entry to the current leaf-level block.
- addEntry(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.LRUDictionary
-
- addExtraHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Add extra headers.
- addFamily(ByteBuffer, AFamilyDescriptor) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- addFamily(ByteBuffer, AFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- addFamily(ByteBuffer, AFamilyDescriptor, Callback<Void>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Get
-
Get all columns from the specified family.
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get all columns from the specified family.
- addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
Does NOT add a column family.
- addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Adds a column family.
- addFileInfoToException(IOException) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- addFilter(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Add a filter.
- addFilterAndArguments(Configuration, Class<? extends Filter>, List<String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Add a Filter to be instantiated on import
- addFlush(List<Pair<Long, Long>>) - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- addGeneralBloomFilter(BloomFilterWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Store general Bloom filter in the file.
- addGeneralBloomFilter(BloomFilterWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV1
-
Version 1 general Bloom filters are stored in two meta blocks with two different
keys.
- addGeneralBloomFilter(BloomFilterWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- addHBaseDependencyJars(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Add HBase and its dependencies (only) to the job configuration.
- addHbaseResources(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
- addHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- addHostsAndBlockWeight(String[], long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
add some weight to a list of hosts, update the value of unique block weight
- addInlineBlockWriter(InlineBlockWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Adds an inline block writer such as a multi-level block index writer or
a compound Bloom filter writer.
- addInlineBlockWriter(InlineBlockWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV1
-
- addInlineBlockWriter(InlineBlockWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- addKey(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- addKeyToZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- addKv(KeyValue) - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Add KeyValue and compress it.
- addLease(Leases.Lease) - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Inserts lease.
- addListener(ForeignExceptionListener) - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
Listen for failures to a given process.
- addLiveNode(String, long, int, int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Add a live node to the cluster representation.
- addLiveNodes(StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- addLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- addLiveNodes(StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- addLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- addLiveNodesBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- addLiveNodesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- addLogToList(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Add a new log to the list of hlogs in zookeeper
- addMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addMaster(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addMaster(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- addOptions() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addOptNoArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addOptWithArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addPeer(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Add a new peer cluster to replicate to.
- addPeer(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Add a new peer to this cluster
- addPlan(String, RegionPlan) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Add a regionPlan for the specified region.
- addPlans(Map<String, RegionPlan>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Add a map of region plans.
- addRegion(byte[], int, int, int, int, int, long, long, int, int, int, long, long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Add a region name to the list
- addRegionInfo(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- addRegions(StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- addRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- addRegions(StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- addRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- addRegions(TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- addRegions(int, TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- addRegions(TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- addRegions(int, TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- addRegionsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- addRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- addRegionsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- addRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- addRegionServer() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addRegionServer(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addRegionServer(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addRegionsInTransition(HRegionInfo, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
String currentAction) throws RegionAlreadyInTransitionException { Add
region to this regionservers list of in transitions regions ONLY if its not
already byte[] encodedName = region.getEncodedNameAsBytes(); in transition.
- addRegionsToMeta(CatalogTracker, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
-
Adds a META row for each of the specified new regions.
- addRegionsToMeta(CatalogTracker, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
Add the specified set of regions to the META table.
- addRegionsToMeta(CatalogTracker, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- addRegionToMeta(CatalogTracker, HRegionInfo) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
-
Adds a META row for the specified new region.
- addRegionToMETA(HRegion, HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Inserts a new region's meta information into the passed
meta
region.
- addRegionToSnapshot(HBaseProtos.SnapshotDescription, ForeignExceptionSnare) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Complete taking the snapshot on the region.
- addRequiredOptWithArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- address - Variable in class org.apache.hadoop.hbase.client.MultiPut
-
Deprecated.
- Addressing - Class in org.apache.hadoop.hbase.util
-
Utility for network addresses, resolving and naming.
- Addressing() - Constructor for class org.apache.hadoop.hbase.util.Addressing
-
- addResult(byte[], int) - Method in class org.apache.hadoop.hbase.client.MultiPutResponse
-
Deprecated.
- addRow(RowModel) - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
Add a row to this cell set
- addRowLock(Integer, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- addRows(CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- addRows(int, CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- addRows(CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- addRows(int, CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- addRowsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- addRowsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- addScanner(ResultScanner) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
Assigns a unique ID to the scanner and adds the mapping to an internal
hash-map.
- addScanner(RegionScanner) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- addScanner(ResultScanner, boolean) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Assigns a unique ID to the scanner and adds the mapping to an internal
hash-map.
- addServer(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- addServer(ServerName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- addServerToDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- addShutdownHook(Thread, int) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- addSlabByConf(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
A way of allocating the desired amount of Slabs of each particular size.
- addSnapshot(long) - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
-
Record a single instance of a snapshot
- addSnapshotClone(long) - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
-
Record a single instance of a snapshot cloned table
- addSnapshotRestore(long) - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
-
Record a single instance of a snapshot
- addSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Add a new normal source to this region server
- addSplit(long, long) - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
-
Record a single instance of a split
- addToCacheSize(BlockType.BlockCategory, long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
Adds the given delta to the cache size for the given block category and
the aggregate metric for all block categories.
- addToColumnFamilies(ColumnDescriptor) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- addToColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- addToColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- addToColumns(TColumnIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- addToColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- addToColumnValues(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- addToColumnValues(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- addToDeletes(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- addToGets(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- addToIncrements(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- addToMutations(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- addToMutations(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- addToMutations(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- addToMutations(TMutation) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- addToOnlineRegions(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- addToPuts(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- addToRowBatches(BatchMutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- addToRowBatches(BatchMutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- addToRows(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- addToRows(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- addToRows(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- addToRows(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- addToSortedColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- addToSuccess(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- addToSuccess(TRegionInfo) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- addToSuccess(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- addToSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- addToSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- addToSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- addTrace(ErrorHandlingProtos.StackTraceElementMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- addTrace(int, ErrorHandlingProtos.StackTraceElementMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- addTrace(ErrorHandlingProtos.StackTraceElementMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- addTrace(int, ErrorHandlingProtos.StackTraceElementMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- addTraceBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- addTraceBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- addValues(CellMessage.Cell) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- addValues(int, CellMessage.Cell) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- addValues(CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- addValues(int, CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- addValuesBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- addValuesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- addWeight(long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
add weight
- ADelete - Class in org.apache.hadoop.hbase.avro.generated
-
- ADelete() - Constructor for class org.apache.hadoop.hbase.avro.generated.ADelete
-
- adeleteToDelete(ADelete) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- admin - Variable in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- admin - Variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- advance() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- advance() - Method in interface org.apache.hadoop.hbase.codec.Decoder
-
Advance the scanner 1 object
- AFamilyDescriptor - Class in org.apache.hadoop.hbase.avro.generated
-
- AFamilyDescriptor() - Constructor for class org.apache.hadoop.hbase.avro.generated.AFamilyDescriptor
-
- afdToHCD(AFamilyDescriptor) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- affixShutdownHook(Thread, int) - Static method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- afterCall() - Method in class org.apache.hadoop.hbase.client.ServerCallable
-
- afterProcess(EventHandler) - Method in interface org.apache.hadoop.hbase.executor.EventHandler.EventHandlerListener
-
Called after any event is processed
- AGet - Class in org.apache.hadoop.hbase.avro.generated
-
- AGet() - Constructor for class org.apache.hadoop.hbase.avro.generated.AGet
-
- agetToGet(AGet) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- AggregateImplementation - Class in org.apache.hadoop.hbase.coprocessor
-
A concrete AggregateProtocol implementation.
- AggregateImplementation() - Constructor for class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- AggregateProtocol - Interface in org.apache.hadoop.hbase.coprocessor
-
Defines the aggregation functions that are to be supported in this
Coprocessor.
- AggregationClient - Class in org.apache.hadoop.hbase.client.coprocessor
-
This client class is for invoking the aggregate functions deployed on the
Region Server side via the AggregateProtocol.
- AggregationClient(Configuration) - Constructor for class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
Constructor with Conf object
- AIllegalArgument - Exception in org.apache.hadoop.hbase.avro.generated
-
- AIllegalArgument() - Constructor for exception org.apache.hadoop.hbase.avro.generated.AIllegalArgument
-
- AIOError - Exception in org.apache.hadoop.hbase.avro.generated
-
- AIOError() - Constructor for exception org.apache.hadoop.hbase.avro.generated.AIOError
-
- align(int) - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Aligns a number to 8.
- align(long) - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Aligns a number to 8.
- ALL_SCHEMA_METRICS - Static variable in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
Metrics for all tables and column families.
- ALL_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Define for 'return-all-versions'.
- allActions() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- allocateBytes(int) - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Allocate a slice of the given length.
- allocBloom() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Allocate memory for the bloom filter data.
- allocBloom() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- allocBloom() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- allPuts() - Method in class org.apache.hadoop.hbase.client.MultiPut
-
Deprecated.
- allTableRegions(Configuration, byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
-
Deprecated.
- allTableRegions(Configuration, HConnection, byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
-
Lists all of the table regions currently in META.
- AlreadyExists - Exception in org.apache.hadoop.hbase.thrift.generated
-
An AlreadyExists exceptions signals that a table with the specified
name already exists
- AlreadyExists() - Constructor for exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- AlreadyExists(String) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- AlreadyExists(AlreadyExists) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
Performs a deep copy on other.
- AlreadyExists._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- AMasterNotRunning - Exception in org.apache.hadoop.hbase.avro.generated
-
- AMasterNotRunning() - Constructor for exception org.apache.hadoop.hbase.avro.generated.AMasterNotRunning
-
- ammount - Variable in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- amount - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- AND - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
AND Byte Array
- AND_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
AND Array
- AND_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- answers - Variable in class org.apache.hadoop.hbase.client.MultiPutResponse
-
Deprecated.
- Append - Class in org.apache.hadoop.hbase.client
-
Performs Append operations on a single row.
- Append() - Constructor for class org.apache.hadoop.hbase.client.Append
-
Constructor for Writable.
- Append(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Append
-
Create a Append operation for the specified row.
- append(Append) - Method in class org.apache.hadoop.hbase.client.HTable
-
Appends values to one or more columns within a single row.
- append(Append) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Appends values to one or more columns within a single row.
- append(KeyValue) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
- append(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
- append(KeyValue) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV1
-
Add key/value to file.
- append(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV1
-
Add key/value to file.
- append(KeyValue) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
Add key/value to file.
- append(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
Add key/value to file.
- append(byte[], Append) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Appends values to one or more columns values in a row.
- append(Append, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Perform one or more append operations on a row.
- append(Append, Integer, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
row locks (lockId) held outside the extent of the operation are deprecated.
- append(byte[], Append) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- append(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- append(HRegionInfo, HLogKey, WALEdit, HTableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Append an entry to the log.
- append(HRegionInfo, byte[], WALEdit, long, HTableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Only used in tests.
- append(HRegionInfo, byte[], WALEdit, UUID, long, HTableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Append a set of edits to the log.
- append(HLog.Entry) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Writer
-
- append(HLog.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
-
- append(Append) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Add to the file info.
- appendFileInfo(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Add an element to the file info map.
- appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- appendKeyValue(StringBuilder, String, Object) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Append to a StringBuilder a key/value.
- appendKeyValue(StringBuilder, String, Object, String, String) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Append to a StringBuilder a key/value.
- appendMetaBlock(String, Writable) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
- appendMetaBlock(String, Writable) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV1
-
Add a meta block to the end of the file.
- appendMetaBlock(String, Writable) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
Add a meta block to the end of the file.
- appendMetadata(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
Writes meta data.
- appendNoSync(HRegionInfo, byte[], WALEdit, UUID, long, HTableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Append a set of edits to the log.
- appendThreadInfo(StringBuilder, ThreadInfo, String) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
Print all of the thread's information and stack traces.
- appendTrackedTimestampsToMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
Add TimestampRange and earliest put timestamp to Metadata
- appliedBatchesRate - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkMetrics
-
Rate of batches (of operations) applied by the sink
- appliedOpsRate - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkMetrics
-
Rate of operations applied by the sink
- applyClusterKeyToConf(Configuration, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Apply the settings in the given key to the given configuration, this is
used to communicate with distant clusters
- APut - Class in org.apache.hadoop.hbase.avro.generated
-
- APut() - Constructor for class org.apache.hadoop.hbase.avro.generated.APut
-
- aputToPut(APut) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- archiveFamily(FileSystem, Configuration, HRegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Remove from the specified region the store files of the specified column family,
either by archiving them or outright deletion
- archiveRegion(Configuration, FileSystem, HRegionInfo) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Cleans up all the files for a HRegion by archiving the HFiles to the
archive directory
- archiveRegion(FileSystem, Path, Path, Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Remove an entire region from the table directory via archiving the region's hfiles.
- archiveStoreFile(FileSystem, HRegionInfo, Configuration, Path, byte[], Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Archive the store file
- archiveStoreFiles(Configuration, FileSystem, HRegion, byte[], Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Remove the store files, either by archiving them or outright deletion
- areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Checks if there are currently any dead servers being processed by the
master.
- areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Checks if any dead servers are currently in progress.
- ARegionLoad - Class in org.apache.hadoop.hbase.avro.generated
-
- ARegionLoad() - Constructor for class org.apache.hadoop.hbase.avro.generated.ARegionLoad
-
- arePartsEqual(ByteBuffer, int, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Check whether two parts in the same buffer are equal.
- AResult - Class in org.apache.hadoop.hbase.avro.generated
-
- AResult() - Constructor for class org.apache.hadoop.hbase.avro.generated.AResult
-
- AResultEntry - Class in org.apache.hadoop.hbase.avro.generated
-
- AResultEntry() - Constructor for class org.apache.hadoop.hbase.avro.generated.AResultEntry
-
- ARRAY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Array overhead
- ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ArrayList(0)
- AScan - Class in org.apache.hadoop.hbase.avro.generated
-
- AScan() - Constructor for class org.apache.hadoop.hbase.avro.generated.AScan
-
- ascanToScan(AScan) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- AServerAddress - Class in org.apache.hadoop.hbase.avro.generated
-
- AServerAddress() - Constructor for class org.apache.hadoop.hbase.avro.generated.AServerAddress
-
- AServerInfo - Class in org.apache.hadoop.hbase.avro.generated
-
- AServerInfo() - Constructor for class org.apache.hadoop.hbase.avro.generated.AServerInfo
-
- AServerLoad - Class in org.apache.hadoop.hbase.avro.generated
-
- AServerLoad() - Constructor for class org.apache.hadoop.hbase.avro.generated.AServerLoad
-
- assertSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- assertSnapshotRequestIsValid(HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Check to make sure that the description of the snapshot requested is valid
- assign(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- assign(byte[], boolean) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
- assign(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Assign a region to a server chosen at random.
- assign(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns the specified region.
- assign(HRegionInfo, boolean, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- assign(HRegionInfo, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- assign(byte[], boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Deprecated.
- assign(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- ASSIGN_SEQ_IDS - Static variable in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- assignAllUserRegions() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns all user regions, if any exist.
- AssignCallable - Class in org.apache.hadoop.hbase.master
-
A callable object that invokes the corresponding action that needs to be
taken for assignment of a region in transition.
- AssignCallable(AssignmentManager, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.master.AssignCallable
-
- AssignmentManager - Class in org.apache.hadoop.hbase.master
-
Manages and performs region assignment.
- AssignmentManager(Server, ServerManager, CatalogTracker, LoadBalancer, ExecutorService) - Constructor for class org.apache.hadoop.hbase.master.AssignmentManager
-
Constructs a new assignment manager.
- assignmentManager - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- assignmentManager - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- AssignmentManager.RegionState - Class in org.apache.hadoop.hbase.master
-
State of a Region while undergoing transitions.
- AssignmentManager.RegionState() - Constructor for class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- AssignmentManager.RegionState.State - Enum in org.apache.hadoop.hbase.master
-
- AssignmentManager.TimeoutMonitor - Class in org.apache.hadoop.hbase.master
-
Monitor to check for time outs on region transition operations
- AssignmentManager.TimeoutMonitor(int, Stoppable, ServerManager, int) - Constructor for class org.apache.hadoop.hbase.master.AssignmentManager.TimeoutMonitor
-
Creates a periodic monitor to check for time outs on region transition
operations.
- AssignmentManager.TimerUpdater - Class in org.apache.hadoop.hbase.master
-
Update timers for all regions in transition going against the server in the
serversInUpdatingTimer.
- AssignmentManager.TimerUpdater(int, Stoppable) - Constructor for class org.apache.hadoop.hbase.master.AssignmentManager.TimerUpdater
-
- AssignmentManagerStatusTmpl - Class in org.apache.hadoop.hbase.tmpl.master
-
- AssignmentManagerStatusTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- AssignmentManagerStatusTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- AssignmentManagerStatusTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.master
-
- AssignmentManagerStatusTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- AssignmentManagerStatusTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.master
-
- AssignmentManagerStatusTmplImpl - Class in org.apache.hadoop.hbase.tmpl.master
-
- AssignmentManagerStatusTmplImpl(TemplateManager, AssignmentManagerStatusTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmplImpl
-
- assignmentZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- assignMeta() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns the META region.
- assignRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- assignRoot() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns the ROOT region.
- assignUserRegions(List<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns all user regions, if any.
- assignUserRegionsToOnlineServers(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns all user regions to online servers.
- assumeUncompressed() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
An additional sanity-check in case no compression is being used.
- asyncCreate(ZooKeeperWatcher, String, byte[], AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Async creates the specified node with the specified data.
- asyncCreateNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates an unassigned node in the OFFLINE state for the specified region.
- ATableDescriptor - Class in org.apache.hadoop.hbase.avro.generated
-
- ATableDescriptor() - Constructor for class org.apache.hadoop.hbase.avro.generated.ATableDescriptor
-
- ATableExists - Exception in org.apache.hadoop.hbase.avro.generated
-
- ATableExists() - Constructor for exception org.apache.hadoop.hbase.avro.generated.ATableExists
-
- atdToHTD(ATableDescriptor) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- ATimeRange - Class in org.apache.hadoop.hbase.avro.generated
-
- ATimeRange() - Constructor for class org.apache.hadoop.hbase.avro.generated.ATimeRange
-
- ATOMIC_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for AtomicBoolean
- ATOMIC_INTEGER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for AtomicInteger
- ATOMIC_LONG - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for AtomicLong
- atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long, AsyncMethodCallback<Hbase.AsyncClient.atomicIncrement_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long, AsyncMethodCallback<Hbase.AsyncClient.atomicIncrement_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Atomically increment the column value specified.
- atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Deprecated.
- atomicIncrement(ByteBuffer, ByteBuffer, byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- atomicIncrementTime - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- attemptingUser - Variable in class org.apache.hadoop.hbase.ipc.SecureServer.SecureConnection
-
- Attributes - Interface in org.apache.hadoop.hbase.client
-
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Delete attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Delete attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Delete attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Delete attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Mutation attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
Mutation attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Mutation attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Mutation attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Scan attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Scan attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Scan attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Scan attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Scan attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Scan attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- ATTRS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- ATTRS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- AUTH_TOKEN_TYPE - Static variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- authenticationFailures - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- AuthenticationKey - Class in org.apache.hadoop.hbase.security.token
-
- AuthenticationKey() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- AuthenticationKey(int, long, SecretKey) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- authenticationMethod - Variable in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.AuthMethod
-
- AuthenticationProtocol - Interface in org.apache.hadoop.hbase.security.token
-
Defines a custom RPC protocol for obtaining authentication tokens
- authenticationSuccesses - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- AuthenticationTokenIdentifier - Class in org.apache.hadoop.hbase.security.token
-
Represents the identity information stored in an HBase authentication token.
- AuthenticationTokenIdentifier() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AuthenticationTokenIdentifier(String) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AuthenticationTokenIdentifier(String, int, long, long) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AuthenticationTokenSecretManager - Class in org.apache.hadoop.hbase.security.token
-
Manages an internal list of secret keys used to sign new authentication
tokens as they are generated, and to valid existing tokens used for
authentication.
- AuthenticationTokenSecretManager(Configuration, ZooKeeperWatcher, String, long, long) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
Create a new secret manager instance for generating keys.
- AuthenticationTokenSelector - Class in org.apache.hadoop.hbase.security.token
-
- AuthenticationTokenSelector() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
-
- authManager - Variable in class org.apache.hadoop.hbase.ipc.SecureServer
-
- authorizationFailures - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- authorizationSuccesses - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- authorize(User, ConnectionHeader, InetAddress) - Method in class org.apache.hadoop.hbase.ipc.SecureServer
-
Authorize the incoming client connection.
- authorize(User, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Authorize a global permission based on ACLs for the given user and the
user's groups.
- authorize(User, byte[], KeyValue, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- authorize(User, byte[], byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- authorize(User, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- authorizeGroup(String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Checks authorization for a given action for a group, based on the stored
permissions.
- authorizeGroup(String, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Checks authorization to a given table and column family for a group, based
on the stored permissions.
- authorizeUser(String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Checks global authorization for a specific action for a user, based on the
stored user permissions.
- authorizeUser(String, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Checks authorization to a given table and column family for a user, based on the
stored user permissions.
- authorizeUser(String, byte[], byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- averageLoad - Variable in class org.apache.hadoop.hbase.avro.generated.AClusterStatus
-
- AVERAGELOAD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- avg(byte[], ColumnInterpreter<R, S>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
This is the client side interface/handle for calling the average method for
a given cf-cq combination.
- avgKeyLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Average key length read from file info
- avgValueLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Average value length read from file info
- AvroServer - Class in org.apache.hadoop.hbase.avro
-
Start an Avro server
- AvroServer() - Constructor for class org.apache.hadoop.hbase.avro.AvroServer
-
- AvroServer.HBaseImpl - Class in org.apache.hadoop.hbase.avro
-
The HBaseImpl is a glue object that connects Avro RPC calls to the
HBase client API primarily defined in the HBaseAdmin and HTable objects.
- AvroUtil - Class in org.apache.hadoop.hbase.avro
-
- AvroUtil() - Constructor for class org.apache.hadoop.hbase.avro.AvroUtil
-
- cache - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- CACHE_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache data blocks on write.
- CACHE_BLOOM_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache compound bloom filter blocks on write.
- CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- CACHE_DATA_BLOCKS_COMPRESSED_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
TODO: Implement this (jgray)
Configuration key to cache data blocks in compressed format.
- CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- CACHE_FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- CACHE_FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- CACHE_INDEX_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache leaf and intermediate-level index blocks on
write.
- CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- Cacheable - Interface in org.apache.hadoop.hbase.io.hfile
-
Cacheable is an interface that allows for an object to be cached.
- CacheableDeserializer<T extends Cacheable> - Interface in org.apache.hadoop.hbase.io.hfile
-
Interface for a deserializer.
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Add block to cache.
- cacheBlock(BlockCacheKey, Cacheable) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Add block to cache (defaults to not in-memory).
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
Cache the block with the specified key and buffer.
- cacheBlock(BlockCacheKey, Cacheable, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
We don't care about whether its in memory or not, so we just pass the call
through.
- cacheBlocks - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Block cache configuration.
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Cache configuration for caching data on write.
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- CacheConfig - Class in org.apache.hadoop.hbase.io.hfile
-
Stores all of the cache objects and configuration for a single HFile.
- CacheConfig(Configuration, HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Create a cache configuration using the specified configuration object and
family descriptor.
- CacheConfig(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Create a cache configuration using the specified configuration object and
defaults for family level settings.
- CacheConfig(CacheConfig) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Constructs a cache configuration copied from the specified configuration.
- CachedBlock - Class in org.apache.hadoop.hbase.io.hfile
-
- CachedBlock(BlockCacheKey, Cacheable, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- CachedBlock(BlockCacheKey, Cacheable, long, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- CachedBlockQueue - Class in org.apache.hadoop.hbase.io.hfile
-
A memory-bound queue that will grow until an element brings
total size >= maxSize.
- CachedBlockQueue(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.CachedBlockQueue
-
- cacheOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- cacheOnWrite() - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
- cacheOnWrite() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- CacheStats - Class in org.apache.hadoop.hbase.io.hfile
-
Class that implements cache metrics.
- CacheStats() - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- CacheStats(int) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- caching - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- caching - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- caching - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- calcCoverage() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
Generates a coverage multimap from split key to Regions that start with the
split key.
- calculateOverhead(long, long, int) - Static method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- call(T) - Method in interface org.apache.hadoop.hbase.client.coprocessor.Batch.Call
-
- call() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- call(Writable, InetSocketAddress) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
Make a call, passing param
, to the IPC server running at
address
, returning the value.
- call(Writable, InetSocketAddress, User, int) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- call(Writable, InetSocketAddress, Class<? extends VersionedProtocol>, User, int) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
Make a call, passing param
, to the IPC server running at
address
which is servicing the protocol
protocol,
with the ticket
credentials, returning the value.
- call(Writable[], InetSocketAddress[]) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- call(Writable[], InetSocketAddress[], Class<? extends VersionedProtocol>, User) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
Makes a set of calls in parallel.
- call(Method, Object[][], InetSocketAddress[], Class<? extends VersionedProtocol>, User, Configuration) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
-
- call(Method, Object[][], InetSocketAddress[], Class<? extends VersionedProtocol>, User, Configuration) - Method in interface org.apache.hadoop.hbase.ipc.RpcEngine
-
Expert: Make multiple, parallel calls to a set of servers.
- call(Class<? extends VersionedProtocol>, Writable, long, MonitoredRPCHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
-
Called for each call.
- call(Method, Object[][], InetSocketAddress[], Class<? extends VersionedProtocol>, User, Configuration) - Method in class org.apache.hadoop.hbase.ipc.SecureRpcEngine
-
Expert: Make multiple, parallel calls to a set of servers.
- call(Class<? extends VersionedProtocol>, Writable, long, MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.SecureRpcEngine.Server
-
- call() - Method in class org.apache.hadoop.hbase.master.AssignCallable
-
- call() - Method in class org.apache.hadoop.hbase.master.UnAssignCallable
-
- call() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
This call is the main execution thread of the barriered procedure.
- call() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- call() - Method in class org.apache.hadoop.hbase.snapshot.CopyRecoveredEditsTask
-
- call() - Method in class org.apache.hadoop.hbase.snapshot.ReferenceRegionHFilesTask
-
- call() - Method in class org.apache.hadoop.hbase.snapshot.ReferenceServerWALsTask
-
Create reference files (empty files with the same path and file name as original).
- call() - Method in class org.apache.hadoop.hbase.snapshot.TableInfoCopyTask
-
- call(Class<T>, T, String, Class[], Object[]) - Static method in class org.apache.hadoop.hbase.util.Methods
-
- callComplete() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Call
-
Indicate when the call is complete and the
value or error are available.
- callComplete() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.ParallelCall
-
Deliver result to result collector.
- 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
-
- callQueue - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- CallQueue - Class in org.apache.hadoop.hbase.thrift
-
A BlockingQueue reports waiting time in queue and queue length to
ThriftMetrics.
- CallQueue(BlockingQueue<CallQueue.Call>, ThriftMetrics) - Constructor for class org.apache.hadoop.hbase.thrift.CallQueue
-
- CallQueue.Call - Class in org.apache.hadoop.hbase.thrift
-
- callQueueLen - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- callQueueSize - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- calls - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- callTimeout - Variable in class org.apache.hadoop.hbase.client.ServerCallable
-
- Canary - Class in org.apache.hadoop.hbase.tool
-
HBase Canary Tool, that that can be used to do
"canary monitoring" of a running HBase cluster.
- Canary() - Constructor for class org.apache.hadoop.hbase.tool.Canary
-
- Canary(Canary.Sink) - Constructor for class org.apache.hadoop.hbase.tool.Canary
-
- Canary.Sink - Interface in org.apache.hadoop.hbase.tool
-
- Canary.StdOutSink - Class in org.apache.hadoop.hbase.tool
-
- Canary.StdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.Canary.StdOutSink
-
- cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- cancel(String) - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Actively cancel a running snapshot.
- cancel(String, Throwable) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Method to cancel the Subprocedure by injecting an exception from and external source.
- CancelableProgressable - Interface in org.apache.hadoop.hbase.util
-
Similar interface as Progressable
but returns
a boolean to support canceling the operation.
- cancelLease(String) - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Client explicitly cancels a lease.
- canQueue() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- canSplit() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- castToReturnType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- castToReturnType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- castToReturnType(T) - Method in interface org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
provides casting opportunity between the data types.
- 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
- CatalogTracker - Class in org.apache.hadoop.hbase.catalog
-
Tracks the availability of the catalog tables -ROOT-
and
.META.
.
- CatalogTracker(Configuration) - Constructor for class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Constructs a catalog tracker.
- CatalogTracker(ZooKeeperWatcher, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Constructs the catalog tracker.
- catalogTracker - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- ceiling(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- cell - Variable in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- 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
-
- cellFromHBase(KeyValue) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a list of Thrift TCell "struct" based on
an Hbase Cell object.
- cellFromHBase(KeyValue[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a list of Thrift TCell "struct" based on
an Hbase Cell array.
- CellMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellMessage.Cell - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellMessage.Cell.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellMessage.CellOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a cell.
- CellModel() - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Default constructor
- CellModel(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor
- CellModel(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor
- CellModel(KeyValue) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor from KeyValue
- CellModel(byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor
- CellModel(byte[], byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor
- CellSetMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellSetMessage.CellSet - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellSetMessage.CellSet.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellSetMessage.CellSet.Row - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellSetMessage.CellSet.Row.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellSetMessage.CellSet.RowOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellSetMessage.CellSetOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellSetModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a grouping of cells.
- CellSetModel() - Constructor for class org.apache.hadoop.hbase.rest.model.CellSetModel
-
Constructor
- CellSetModel(List<RowModel>) - Constructor for class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- CF_BAD_FAMILY_PREFIX - Static variable in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- CF_PREFIX - Static variable in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- CF_UNKNOWN_PREFIX - Static variable in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- CFNAME - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- ChangedReadersObserver - Interface in org.apache.hadoop.hbase.regionserver
-
If set of MapFile.Readers in Store change, implementors are notified.
- changeOnlineStatus(Configuration, byte[], boolean) - Static method in class org.apache.hadoop.hbase.util.MetaUtils
-
Set a single region on/offline.
- channel - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- channelRead(ReadableByteChannel, ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- channelWrite(WritableByteChannel, ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- check(Put) - Method in interface org.apache.hadoop.hbase.constraint.Constraint
-
Check a
Put
to ensure it is valid for the table.
- checkAccess(User, FileStatus, FsAction) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Throw an exception if an action is not permitted by a user on a file.
- 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[], byte[], Delete) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Atomically checks if a row/family/qualifier value match the expectedValue.
- checkAndDelete(byte[], byte[], byte[], byte[], CompareFilter.CompareOp, WritableByteArrayComparable, Delete) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Atomically checks if a row/family/qualifier value match the expectedValue.
- checkAndDelete(byte[], byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- checkAndDelete(byte[], byte[], byte[], byte[], CompareFilter.CompareOp, WritableByteArrayComparable, Delete) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, AsyncMethodCallback<THBaseService.AsyncClient.checkAndDelete_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, AsyncMethodCallback<THBaseService.AsyncClient.checkAndDelete_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, WritableByteArrayComparable, Writable, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, WritableByteArrayComparable, Writable, Integer, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
row locks (lockId) held outside the extent of the operation are deprecated.
- 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[], byte[], Put) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Atomically checks if a row/family/qualifier value match the expectedValue.
- checkAndPut(byte[], byte[], byte[], byte[], CompareFilter.CompareOp, WritableByteArrayComparable, Put) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Atomically checks if a row/family/qualifier value match the expectedValue.
- checkAndPut(byte[], byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- checkAndPut(byte[], byte[], byte[], byte[], CompareFilter.CompareOp, WritableByteArrayComparable, Put) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, AsyncMethodCallback<THBaseService.AsyncClient.checkAndPut_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, AsyncMethodCallback<THBaseService.AsyncClient.checkAndPut_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- checkAndSetEnablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the specified table as ENABLING in zookeeper atomically
If the table is already in ENABLING state, no operation is performed
- checkClusterIdExists(FileSystem, Path, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks that a cluster ID file exists in the HBase root directory
- checkColFamDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Check all files in a column family dir.
- checkColumn(byte[], int, int, byte) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Checks if the column is present in the list of requested columns by returning the match code
instance.
- checkColumn(byte[], int, int, byte) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
Checks if the column is present in the list of requested columns by returning the match code
instance.
- checkColumn(byte[], int, int, byte) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
Checks if the column is present in the list of requested columns by returning the match code
instance.
- checkCompressedSize(Compressor, byte[], int, int) - Static method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Find the size of compressed data assuming that buffer will be compressed
using given algorithm.
- checkCompressedSize(Compressor) - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Estimate size after second stage of compression (e.g.
- checkDfsSafeMode(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Check whether dfs is in safemode.
- checkdir(FileSystem, Path) - Method in class org.apache.hadoop.hbase.util.FSUtils
-
Check if directory exists.
- checkDisabledAndSetEnablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the specified table as ENABLING in zookeeper atomically
If the table isn't in DISABLED state, no operation is performed
- checkEnabledAndSetDisablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the specified table as DISABLING in zookeeper atomically
If the table isn't in ENABLED state, no operation is performed
- checkExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Check if the specified node exists.
- checkFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Checks to see if the file system is still accessible.
- checkFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Checks to see if the file system is still accessible.
- checkFileSystemAvailable(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks to see if the specified file system is available
- checkFlushed() - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
-
- 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'
- checkFormatVersion(int) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Checks the given
HFile
format version, and throws an exception if
invalid.
- 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.
- checkHFile(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Checks a path to see if it is a valid hfile.
- checkIfBaseNodeAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Checks if the baseznode set as per the property 'zookeeper.znode.parent'
exists.
- checkIOException(IOException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
-
Examine passed IOException.
- checkKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Checks that the given key does not violate the key order.
- checkOOME(Throwable) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandler
-
Take actions on the event of an OutOfMemoryError.
- checkOOME(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- checkOpen() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Called to verify that this server is up and 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.
- checkPermissions(Permission[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- checkPermissions(Permission[]) - Method in interface org.apache.hadoop.hbase.security.access.AccessControllerProtocol
-
Checks whether the given Permissions will pass the access checks for the
current user.
- checkReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkRegionBoundaries() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- checkRegionChain(TableIntegrityErrorHandler) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
Check the region chain (from META) of this table.
- checkRegionDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Check all column families in a region dir.
- checkScanStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- checkSnapshotSupport() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Throws an exception if snapshot operations (take a snapshot, restore, clone) are not supported.
- checkSplit() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Return the splitpoint.
- 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.
- ChecksumFactory - Class in org.apache.hadoop.hbase.util
-
Utility class that is used to generate a Checksum object.
- ChecksumFactory() - Constructor for class org.apache.hadoop.hbase.util.ChecksumFactory
-
- checksumFailuresCount - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
Number of times checksum verification failed.
- checksumType - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- checksumType - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
Checksum type
- ChecksumType - Enum in org.apache.hadoop.hbase.util
-
Checksum types.
- ChecksumUtil - Class in org.apache.hadoop.hbase.io.hfile
-
Utility methods to compute and validate checksums.
- ChecksumUtil() - Constructor for class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
-
- checkTableModifiable(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- checkTableModifiable(byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Check table is modifiable; i.e.
- checkTables(Collection<Path>) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Check the specified table dirs for bad hfiles.
- checkThrowable(Throwable) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
-
Examine passed Throwable.
- checkType(TMutation._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- checkValue(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Checks the given value for validity.
- checkVersion(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies current version of file system
- checkVersion(FileSystem, Path, boolean, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies current version of file system
- checkVersions(byte[], int, int, long, byte, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Keeps track of the number of versions for the columns asked for.
- checkVersions(byte[], int, int, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
- checkVersions(byte[], int, int, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
Keeps track of the number of versions for the columns asked for.
- Chore - Class in org.apache.hadoop.hbase
-
Chore is a task performed on a period in hbase.
- Chore(String, int, Stoppable) - Constructor for class org.apache.hadoop.hbase.Chore
-
- chore() - Method in class org.apache.hadoop.hbase.Chore
-
Look for chores.
- chore() - Method in class org.apache.hadoop.hbase.HealthCheckChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.TimeoutMonitor
-
- chore() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.TimerUpdater
-
- chore() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- choreForTesting() - Method in class org.apache.hadoop.hbase.Chore
-
- CLASS_TO_CODE - Static variable in interface org.apache.hadoop.hbase.io.CodeToClassAndBack
-
Static map that contains mapping from class to code
- Classes - Class in org.apache.hadoop.hbase.util
-
Utilities for class manipulation.
- Classes() - Constructor for class org.apache.hadoop.hbase.util.Classes
-
- classifyExs(List<Throwable>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- classList - Static variable in interface org.apache.hadoop.hbase.io.CodeToClassAndBack
-
Class list for supported classes
- ClassLoaderBase - Class in org.apache.hadoop.hbase.util
-
Base class loader that defines couple shared constants used
by sub-classes.
- ClassLoaderBase(ClassLoader) - Constructor for class org.apache.hadoop.hbase.util.ClassLoaderBase
-
Creates a DynamicClassLoader that can load classes dynamically
from jar files under a specific folder.
- CLASSNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- ClassSize - Class in org.apache.hadoop.hbase.util
-
Class for determining the "size" of a class, an attempt to calculate the
actual bytes that an object of this class will occupy in memory
The core of this class is taken from the Derby project
- ClassSize() - Constructor for class org.apache.hadoop.hbase.util.ClassSize
-
- CleanerChore<T extends FileCleanerDelegate> - Class in org.apache.hadoop.hbase.master.cleaner
-
Abstract Cleaner that uses a chain of delegates to clean a directory of files
- CleanerChore(String, int, Stoppable, Configuration, FileSystem, Path, String) - Constructor for class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- cleanOldLogs(String, String, boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Cleans a log file and all older files from ZK.
- cleanPreviousInstance(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
A dead server that comes back alive has a different start code.
- cleanup() - Method in class org.apache.hadoop.hbase.Chore
-
Called when the chore has completed, allowing subclasses to cleanup any
extra overhead
- cleanup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- cleanup() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
Explicitly mark this status as able to be cleaned up,
even though it might not be complete.
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Users should override this method.
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
Cancel threads if they haven't finished.
- cleanupBulkLoad(String) - Method in class org.apache.hadoop.hbase.coprocessor.SecureBulkLoadClient
-
- cleanupBulkLoad(String) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- cleanupBulkLoad(String) - Method in interface org.apache.hadoop.hbase.security.access.SecureBulkLoadProtocol
-
Cleanup after bulk load.
- cleanupCalls() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- cleanupCalls(long) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- clear() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- clear() - Static method in class org.apache.hadoop.hbase.ipc.RequestContext
-
Clears out the client credentials for a given request.
- clear() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- clear() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
-
Clears all recorded values.
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Clears all entries from the map.
- clear(String) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
Clear the timevarying and numeric metrics for all regions in this region server
Clear the numericPersistentMerics for only the region being closed.
- clear() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerDynamicMetrics
-
Clear all metrics this exposes.
- clear() - Method in class org.apache.hadoop.hbase.regionserver.wal.LRUDictionary
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- clear() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- clear() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- clear() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- clear() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- clear() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- clear() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- clear() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- clear() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- clear() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- clear() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- clearAttrs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- clearAttrs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- clearAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- clearBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- clearCache() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Clears the cache.
- clearCache() - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- clearCaches(String) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Clear any caches that pertain to server name sn
- clearChildZNodes() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- clearClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- clearColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- clearColumns() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- clearColumns() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- clearCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- clearCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- clearCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- clearDeadNodes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- clearDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- clearEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- clearEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- clearEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- clearErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- clearFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- clearFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- clearFromTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- clearGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- clearHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- clearId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- clearInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- clearInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- clearJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- clearJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- clearKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- clearLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- clearLiveNodes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- clearLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- clearMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- clearMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- clearMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- clearMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- clearMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- clearOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- clearReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- clearReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Allows flushing the region cache.
- clearRegionCache(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Allows flushing the region cache of all locations that pertain to
tableName
- clearRegionCache() - Method in class org.apache.hadoop.hbase.client.HTable
-
Explicitly clears the region cache to fetch the latest value from META.
- clearRegionFromTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- clearRegionReplayEditsSize(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Clear a region from replayEditsPerRegion.
- clearRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- clearRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- clearRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- clearRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- clearRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- clearRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- clearRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- clearRows() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- clearServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- clearSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- clearStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- clearStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- clearStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- clearStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- clearStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearSubList(int, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactSelection
-
- clearTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- clearTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- clearTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- clearTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- clearType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- clearValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- clearValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- clearValues() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- clearVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- clearWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clearZNodes(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- 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_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, byte[]) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
Create a new ClientScanner for the specified table.
- ClientScanner(Configuration, Scan, byte[], 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.
- ClientSmallScanner - Class in org.apache.hadoop.hbase.client
-
Client scanner for small scan.
- ClientSmallScanner(Configuration, Scan, byte[]) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallScanner
-
Create a new ClientSmallScanner for the specified table.
- ClientSmallScanner(Configuration, Scan, byte[], HConnection) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallScanner
-
Create a new ClientSmallScanner for the specified table.
- clientTableZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- ClockOutOfSyncException - Exception in org.apache.hadoop.hbase
-
This exception is thrown by the master when a region server clock skew is
too high.
- ClockOutOfSyncException(String) - Constructor for exception org.apache.hadoop.hbase.ClockOutOfSyncException
-
- clone() - Method in class org.apache.hadoop.hbase.KeyValue
-
Clones a KeyValue.
- clone() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- clone() - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
- clone() - Method in class org.apache.hadoop.hbase.KeyValue.RootComparator
-
- clone() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- clone() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- clone() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
Public exposure of Object.clone() in order to allow clients to easily
capture current state.
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- cloneRegionInfo(HRegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Create a new
HRegionInfo
from the snapshot region info.
- cloneSnapshot(byte[], byte[]) - 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.
- CloneSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
-
Handler to Clone a snapshot.
- CloneSnapshotHandler(MasterServices, HBaseProtos.SnapshotDescription, HTableDescriptor, MasterMetrics) - Constructor for class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- cloneTableSchema(HTableDescriptor, byte[]) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Create a new table descriptor cloning the snapshot table schema.
- close() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- 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
-
Releases any resources help or pending changes in internal buffers.
- close() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Releases any resources help or pending changes in internal buffers.
- close() - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Closes all the HTable instances , belonging to all tables in the table
pool.
- close() - Method in class org.apache.hadoop.hbase.client.MetaScanner.BlockingMetaScannerVisitor
-
- close() - Method in class org.apache.hadoop.hbase.client.MetaScanner.MetaScannerVisitorBase
-
- close() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Closes the scanner and releases any resources it has allocated
- close() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Close this filesystem object
- close() - Method in class org.apache.hadoop.hbase.io.DoubleOutputStream
-
- close(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Close method with optional evictOnClose
- close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1
-
- close(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1
-
- close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- close(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV1
-
- close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- close() - Method in class org.apache.hadoop.hbase.io.hfile.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
- close() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
Close the connection.
- close() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- close(long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Close a scanner
- close() - Method in interface org.apache.hadoop.hbase.ipc.RpcEngine
-
Shutdown this instance
- close() - Method in class org.apache.hadoop.hbase.ipc.SecureClient.SecureConnection
-
Close the connection.
- close() - Method in class org.apache.hadoop.hbase.ipc.SecureRpcEngine
-
- close() - Method in class org.apache.hadoop.hbase.ipc.SecureServer.SecureConnection
-
- close(Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
-
Deprecated.
- close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
- close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
-
Closes the writer, in this case flush table commits.
- 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.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionRecordReader
-
- close() - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Shutdown the thread pools and release rpc resources
- close() - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Best effort attempt to close the threadpool via Thread.interrupt.
- close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
- close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Close down this HRegion.
- close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Close down this HRegion.
- close(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
-
Closes the scanner and releases any resources it has allocated
- close() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Close the KeyValue scanner.
- close() - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Shut down this Leases instance.
- close() - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
-
- close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Shut down the log.
- close() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Reader
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Writer
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
-
- close() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- close() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- close() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- close() - Method in class org.apache.hadoop.hbase.rest.ResultGenerator
-
- close() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
-
- close() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- close() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
-
Flushes and closes (I think, in the superclass) the stream.
- close() - Method in class org.apache.hadoop.hbase.util.ByteBufferOutputStream
-
- close() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- close() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- close() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Close the connection to ZooKeeper.
- closeAfterLeasesExpire() - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Shuts down this lease instance when all outstanding leases expire.
- closeAllRegions(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Closes all regions.
- closeAndDelete() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Shut down the log and delete the log directory
- closeConnection() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- closeConnection(HBaseServer.Connection) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- closed - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- closed - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- ClosedRegionHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handles CLOSED region event on Master.
- ClosedRegionHandler(Server, AssignmentManager, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
-
- closeException - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- closeHRegion(HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- closeIStream - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
True if we should close the input stream when done.
- CloseMetaHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handles closing of the root region on a region server.
- CloseMetaHandler(Server, RegionServerServices, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseMetaHandler
-
- CloseMetaHandler(Server, RegionServerServices, HRegionInfo, boolean, boolean, int) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseMetaHandler
-
- closeMetrics(String) - Method in class org.apache.hadoop.hbase.regionserver.metrics.OperationMetrics
-
This deletes all old non-persistent metrics this instance has ever created or updated.
- closeOutputStream - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
True if we opened the outputStream
(and so will close it).
- closeReader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- closeReader() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
-
Close the current reader
- closeRecoveredQueue(ReplicationSourceInterface) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Clear the references to the specified old source
- closeRegion(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Close a region.
- closeRegion(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Close a region.
- closeRegion(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Close a region.
- closeRegion(HRegionInfo) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Closes the specified region.
- closeRegion(HRegionInfo, int) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Closes the specified region.
- closeRegion(HRegionInfo, boolean) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Closes the specified region and will use or not use ZK during the close
according to the specified flag.
- closeRegion(byte[], boolean) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Closes the region in the RS with the specified encoded regionName and will
use or not use ZK during the close according to the specified flag.
- closeRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- closeRegion(HRegionInfo, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- closeRegion(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- closeRegion(HRegionInfo, boolean, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- closeRegion(byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- closeRegion(HRegionInfo, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- closeRegion(HRegionInfo, boolean, boolean, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- closeRegion(byte[], boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- CloseRegionHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handles closing of a region on a region server.
- CloseRegionHandler(Server, RegionServerServices, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, boolean, int) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
This method used internally by the RegionServer to close out regions.
- CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, boolean, int, EventHandler.EventType) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- closeRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Closes the lock.
- closeRegionSilentlyAndWait(HBaseAdmin, ServerName, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Contacts a region server and waits up to hbase.hbck.close.timeout ms
(default 120s) to close the region.
- closeRegionWithEncodedRegionName(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
For expert-admins.
- CloseRootHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handles closing of the root region on a region server.
- CloseRootHandler(Server, RegionServerServices, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRootHandler
-
- CloseRootHandler(Server, RegionServerServices, HRegionInfo, boolean, boolean, int) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRootHandler
-
- closeScanner(int, AsyncMethodCallback<THBaseService.AsyncClient.closeScanner_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- closeScanner(int, AsyncMethodCallback<THBaseService.AsyncClient.closeScanner_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- closeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- closeScanner(int) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Closes the scanner.
- closeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- closeTablePool(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Closes all the HTable instances , belonging to the given table, in the
table pool.
- closeTablePool(byte[]) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
- 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 - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key storing the 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
- clusterId - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- ClusterId - Class in org.apache.hadoop.hbase.zookeeper
-
Publishes and synchronizes a unique identifier specific to a given HBase
cluster.
- ClusterId(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ClusterId
-
- clusterIdZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- clusterStateZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- ClusterStatus - Class in org.apache.hadoop.hbase
-
Status information on the HBase cluster.
- ClusterStatus() - Constructor for class org.apache.hadoop.hbase.ClusterStatus
-
Constructor, for Writable
- ClusterStatus(String, String, Map<ServerName, HServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, Map<String, AssignmentManager.RegionState>, String[]) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
-
- ClusterStatusTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracker on cluster settings up in zookeeper.
- ClusterStatusTracker(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Creates a cluster status tracker.
- cmdLineArgs - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- code() - Method in enum org.apache.hadoop.hbase.security.access.Permission.Action
-
- code - Variable in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.AuthMethod
-
The code for this method.
- CODE_TO_CLASS - Static variable in interface org.apache.hadoop.hbase.io.CodeToClassAndBack
-
Static map that contains mapping from code to class
- Codec - Interface in org.apache.hadoop.hbase.codec
-
Encoder/Decoder for KeyValue.
- CodecException - Exception in org.apache.hadoop.hbase.codec
-
Thrown when problems in the codec whether setup or context.
- CodecException() - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
-
- CodecException(String) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
-
- CodecException(Throwable) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
-
- CodecException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
-
- CodeToClassAndBack - Interface in org.apache.hadoop.hbase.io
-
A Static Interface.
- CodeToClassAndBack.InternalStaticLoader - Class in org.apache.hadoop.hbase.io
-
Class that loads the static maps with their values.
- codeToType(byte) - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
-
Cannot rely on enum ordinals .
- codeToType(byte) - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
-
Cannot rely on enum ordinals .
- colDescFromHbase(HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a new Thrift ColumnDescriptor "struct" based on
an Hbase HColumnDescriptor object.
- colDescFromThrift(ColumnDescriptor) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a new Hbase HColumnDescriptor object based on a
Thrift ColumnDescriptor "struct".
- CollectionBackedScanner - Class in org.apache.hadoop.hbase.util
-
Utility scanner that wraps a sortable collection and serves
as a KeyValueScanner.
- CollectionBackedScanner(SortedSet<KeyValue>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(SortedSet<KeyValue>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(List<KeyValue>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(List<KeyValue>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(KeyValue.KVComparator, KeyValue...) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- COLON - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for colon (:)
- COLUMN - Static variable in interface org.apache.hadoop.hbase.coprocessor.example.BulkDeleteProtocol.DeleteType
-
Delete full column(s).
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
name of column
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
name of column whose value is to be deleted
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
name of column whose value is to be deleted
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
column name
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
column name
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
column name
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- COLUMN_FAMILY_DELIM_ARRAY - Static variable in class org.apache.hadoop.hbase.KeyValue
-
- COLUMN_FAMILY_DELIMITER - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Colon character in UTF-8
- COLUMN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- COLUMN_LIST - Static variable in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
Deprecated.
space delimited list of columns
- ColumnCount - Class in org.apache.hadoop.hbase.regionserver
-
Simple wrapper for a byte buffer and a counter.
- ColumnCount(byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Constructor
- ColumnCount(byte[], int) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Constructor
- ColumnCount(byte[], int, int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Constuctor
- ColumnCountGetFilter - Class in org.apache.hadoop.hbase.filter
-
Simple filter that returns first N columns on row only.
- ColumnCountGetFilter() - Constructor for class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
Used during serialization.
- ColumnCountGetFilter(int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- ColumnDescriptor - Class in org.apache.hadoop.hbase.thrift.generated
-
An HColumnDescriptor contains information about a column family
such as the number of versions, compression settings, etc.
- ColumnDescriptor() - Constructor for class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- ColumnDescriptor(ByteBuffer, int, String, boolean, String, int, int, boolean, int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- ColumnDescriptor(ColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
Performs a deep copy on other.
- ColumnDescriptor._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- columnFamilies - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
list of column family descriptors
- columnFamily - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- columnFamily - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- ColumnInterpreter<T,S> - Interface in org.apache.hadoop.hbase.coprocessor
-
Defines how value for specific column is interpreted and provides utility
methods like compare, add, multiply etc for them.
- columnName - Variable in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- ColumnPaginationFilter - Class in org.apache.hadoop.hbase.filter
-
A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
- ColumnPaginationFilter() - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
Used during serialization.
- ColumnPaginationFilter(int, int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- 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() - Constructor for class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- 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() - Constructor for class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- 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.avro.generated.ADelete
-
- columns - Variable in class org.apache.hadoop.hbase.avro.generated.AGet
-
- columns - Variable in class org.apache.hadoop.hbase.avro.generated.AScan
-
- 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 - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
List of columns to return, null for all columns
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
List of columns to return, null for all columns
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
List of columns to return, null for all columns
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
List of columns to return, null for all columns
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
columns to scan.
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
columns to scan.
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
the columns you want returned
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
columns to scan.
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
columns to scan.
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- COLUMNS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- COLUMNS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- ColumnSchemaMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ColumnSchemaMessage.ColumnSchema - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ColumnSchemaMessage.ColumnSchema.Attribute - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ColumnSchemaMessage.ColumnSchema.Attribute.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ColumnSchemaMessage.ColumnSchema.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ColumnSchemaMessage.ColumnSchemaOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ColumnSchemaModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a column family schema.
- ColumnSchemaModel() - Constructor for class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
Default constructor
- ColumnTracker - Interface in org.apache.hadoop.hbase.regionserver
-
Implementing classes of this interface will be used for the tracking
and enforcement of columns and numbers of versions and timeToLive during
the course of a Get or Scan operation.
- columnValues - Variable in class org.apache.hadoop.hbase.avro.generated.APut
-
- columnValues - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- columnValues - Variable in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- 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.
- compact(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- compact(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.compact_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- compact(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.compact_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- compact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- compact(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
- compact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- compactBloom() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Compact the Bloom filter before writing metadata & data to disk.
- compactBloom() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- compactBloom() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- 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
- CompactionProgress - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This class holds information relevant for tracking the progress of a
compaction.
- CompactionProgress(long) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Constructor
- compactionQueueSize - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
Size of the compaction queue.
- CompactionRequest - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This class holds all details necessary to run a compaction.
- CompactionRequest(HRegion, Store, int) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Constructor for a custom compaction.
- CompactionRequest(HRegion, Store, CompactSelection, boolean, int) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- CompactionRequest.CompactionState - Enum in org.apache.hadoop.hbase.regionserver.compactions
-
An enum for the region compaction state
- CompactionRequest.Rejection - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Cleanup class to use when rejecting a compaction request from the queue.
- CompactionRequest.Rejection() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest.Rejection
-
- CompactionRequestor - Interface in org.apache.hadoop.hbase.regionserver
-
- compactionSize - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- compactionTime - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
time each scheduled compaction takes
- CompactionTool - Class in org.apache.hadoop.hbase.regionserver
-
- CompactionTool() - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- compactRecentForTesting(int) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
Compact the most recent N files.
- compactRegion(HRegionInfo, boolean) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Compacts the specified region.
- compactRegion(HRegionInfo, boolean, byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Compacts a column-family within a specified region.
- compactRegion(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- compactRegion(HRegionInfo, boolean, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- CompactSelection - Class in org.apache.hadoop.hbase.regionserver.compactions
-
- CompactSelection(Configuration, List<StoreFile>) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactSelection
-
- CompactSplitThread - Class in org.apache.hadoop.hbase.regionserver
-
Compact region on request and then run split if appropriate
- compactSplitThread - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- compactStores(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function that compact all the stores synchronously
It is used by utilities and testing
- compactStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function that compact all the stores synchronously
It is used by utilities and testing
- comparator - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
-
- comparator() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- comparator - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Key comparator
- comparator - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Key comparator.
- comparator - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Comparator for plain key/values; i.e.
- comparator() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- comparator - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
Comparator used to compare Bloom filter keys
- comparator() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- comparator() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- compare(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- compare(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- compare(T, T) - Method in interface org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This takes care if either of arguments are null.
- compare(HDFSBlocksDistribution.HostAndWeight, HDFSBlocksDistribution.HostAndWeight) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
-
- compare(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Compare the timestamp to timerange
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
-
- compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
-
- compare(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compare(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.RowComparator
-
- compare(Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.LogsComparator
-
- compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
-
- compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
-
- compareColumns(byte[], int, int, int, byte[], int, int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
-
- compareColumns(KeyValue, byte[], int, int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- CompareFilter - Class in org.apache.hadoop.hbase.filter
-
This is a generic filter to be used to filter by comparison.
- CompareFilter() - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
-
Writable constructor, do not use.
- CompareFilter(CompareFilter.CompareOp, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
-
Constructor.
- CompareFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
-
Comparison operators.
- compareIgnoringPrefix(int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
-
Compare the two key-values, ignoring the prefix of the given length
that is known to be the same between the two.
- compareIgnoringPrefix(int, T, int, int, T, int, int) - Method in interface org.apache.hadoop.hbase.KeyValue.SamePrefixComparator
-
Compare two keys assuming that the first n bytes are the same.
- compareKey(RawComparator<byte[]>, byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Compare the given key against the current key
- compareKey(RawComparator<byte[]>, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
Compare the given key against the current key
- compareKey(RawComparator<byte[]>, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- compareKey(RawComparator<byte[]>, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- compareOp - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
-
- 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.
- compareRowid(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.MetaKeyComparator
-
- compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyComparator
-
- compareRows(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compareRows(KeyValue, short, KeyValue, short) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compareRows(KeyValue, byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.MetaKeyComparator
-
- compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.RootKeyComparator
-
- compareTimestamps(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compareTo(Object) - Method in class org.apache.hadoop.hbase.client.Action
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.coprocessor.Exec
-
- 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(Runnable) - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Default prioritized runnable comparator which implements a FIFO ordering.
- 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.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(byte[]) - Method in class org.apache.hadoop.hbase.filter.WritableByteArrayComparable
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.WritableByteArrayComparable
-
Special compareTo method for subclasses, to avoid
copying byte[] unnecessarily.
- 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(HServerAddress) - Method in class org.apache.hadoop.hbase.HServerAddress
-
Deprecated.
- compareTo(HServerInfo) - Method in class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
- compareTo(HServerLoad) - Method in class org.apache.hadoop.hbase.HServerLoad
-
- compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Compares the descriptor with another descriptor which is passed as a parameter.
- compareTo(BlockCacheColumnFamilySummary) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- compareTo(CachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- 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(RegionPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Compare the region info.
- compareTo(HRegionInfo090x) - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- compareTo(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
This function will define where in the priority queue the request will
end up.
- compareTo(HLogKey) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
- compareTo(ServerName) - Method in class org.apache.hadoop.hbase.ServerName
-
- compareTo(AlreadyExists) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- compareTo(BatchMutation) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- compareTo(ColumnDescriptor) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- compareTo(Hbase.atomicIncrement_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- compareTo(Hbase.atomicIncrement_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- compareTo(Hbase.compact_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- compareTo(Hbase.compact_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- compareTo(Hbase.createTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- compareTo(Hbase.createTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- compareTo(Hbase.deleteAll_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- compareTo(Hbase.deleteAll_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- compareTo(Hbase.deleteAllRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- compareTo(Hbase.deleteAllRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- compareTo(Hbase.deleteAllRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- compareTo(Hbase.deleteAllRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- compareTo(Hbase.deleteAllTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- compareTo(Hbase.deleteAllTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- compareTo(Hbase.deleteTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- compareTo(Hbase.deleteTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- compareTo(Hbase.disableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- compareTo(Hbase.disableTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- compareTo(Hbase.enableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- compareTo(Hbase.enableTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- compareTo(Hbase.get_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- compareTo(Hbase.get_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- compareTo(Hbase.getColumnDescriptors_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- compareTo(Hbase.getColumnDescriptors_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- compareTo(Hbase.getRegionInfo_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- compareTo(Hbase.getRegionInfo_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- compareTo(Hbase.getRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- compareTo(Hbase.getRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- compareTo(Hbase.getRowOrBefore_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- compareTo(Hbase.getRowOrBefore_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- compareTo(Hbase.getRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- compareTo(Hbase.getRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- compareTo(Hbase.getRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- compareTo(Hbase.getRowsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- compareTo(Hbase.getRowsWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- compareTo(Hbase.getRowsWithColumns_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- compareTo(Hbase.getRowsWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- compareTo(Hbase.getRowsWithColumnsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- compareTo(Hbase.getRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- compareTo(Hbase.getRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- compareTo(Hbase.getRowWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- compareTo(Hbase.getRowWithColumns_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- compareTo(Hbase.getRowWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- compareTo(Hbase.getRowWithColumnsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- compareTo(Hbase.getTableNames_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- compareTo(Hbase.getTableNames_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- compareTo(Hbase.getTableRegions_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- compareTo(Hbase.getTableRegions_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- compareTo(Hbase.getVer_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- compareTo(Hbase.getVer_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- compareTo(Hbase.getVerTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- compareTo(Hbase.getVerTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- compareTo(Hbase.increment_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- compareTo(Hbase.increment_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- compareTo(Hbase.incrementRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- compareTo(Hbase.incrementRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- compareTo(Hbase.isTableEnabled_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- compareTo(Hbase.isTableEnabled_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- compareTo(Hbase.majorCompact_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- compareTo(Hbase.majorCompact_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- compareTo(Hbase.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- compareTo(Hbase.mutateRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- compareTo(Hbase.mutateRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- compareTo(Hbase.mutateRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- compareTo(Hbase.mutateRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- compareTo(Hbase.mutateRowsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- compareTo(Hbase.mutateRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- compareTo(Hbase.mutateRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- compareTo(Hbase.scannerClose_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- compareTo(Hbase.scannerClose_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- compareTo(Hbase.scannerGet_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- compareTo(Hbase.scannerGet_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- compareTo(Hbase.scannerGetList_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- compareTo(Hbase.scannerGetList_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- compareTo(Hbase.scannerOpen_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- compareTo(Hbase.scannerOpen_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- compareTo(Hbase.scannerOpenTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- compareTo(Hbase.scannerOpenTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- compareTo(Hbase.scannerOpenWithPrefix_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- compareTo(Hbase.scannerOpenWithPrefix_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- compareTo(Hbase.scannerOpenWithScan_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- compareTo(Hbase.scannerOpenWithScan_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- compareTo(Hbase.scannerOpenWithStop_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- compareTo(Hbase.scannerOpenWithStop_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- compareTo(Hbase.scannerOpenWithStopTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- compareTo(Hbase.scannerOpenWithStopTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- compareTo(IllegalArgument) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- compareTo(IOError) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- compareTo(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- compareTo(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- compareTo(TColumn) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- compareTo(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- compareTo(TRegionInfo) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- compareTo(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- compareTo(TScan) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- compareTo(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- compareTo(TColumnIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- compareTo(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- compareTo(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- compareTo(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- compareTo(THBaseService.checkAndDelete_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- compareTo(THBaseService.checkAndDelete_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- compareTo(THBaseService.checkAndPut_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- compareTo(THBaseService.checkAndPut_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- compareTo(THBaseService.closeScanner_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- compareTo(THBaseService.closeScanner_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- compareTo(THBaseService.deleteMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- compareTo(THBaseService.deleteMultiple_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- compareTo(THBaseService.deleteSingle_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- compareTo(THBaseService.deleteSingle_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- compareTo(THBaseService.exists_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- compareTo(THBaseService.exists_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- compareTo(THBaseService.get_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- compareTo(THBaseService.get_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- compareTo(THBaseService.getMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- compareTo(THBaseService.getMultiple_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- compareTo(THBaseService.getScannerResults_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- compareTo(THBaseService.getScannerResults_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- compareTo(THBaseService.getScannerRows_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- compareTo(THBaseService.getScannerRows_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- compareTo(THBaseService.increment_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- compareTo(THBaseService.increment_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- compareTo(THBaseService.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- compareTo(THBaseService.mutateRow_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- compareTo(THBaseService.openScanner_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- compareTo(THBaseService.openScanner_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- compareTo(THBaseService.put_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- compareTo(THBaseService.put_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- compareTo(THBaseService.putMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- compareTo(THBaseService.putMultiple_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- compareTo(TIllegalArgument) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- compareTo(TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- compareTo(TIOError) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- compareTo(TMutation) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- compareTo(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- compareTo(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- compareTo(TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- compareTo(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- compareTo(TTimeRange) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- 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.
- complete() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
Call to indicate that additional coprocessors further down the execution
chain do not need to be invoked.
- complete() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
For all time forward, do not throw an error because the process has completed.
- completeCacheFlush(byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Complete the cache flush
Protected by cacheFlushLock
- completed(Throwable) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
Called after that process() is completed.
- completed(Throwable) - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
Called after that process() is completed.
- completed(Throwable) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- completed(Throwable) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- completeMemstoreInsert(MultiVersionConsistencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
- completeSnapshot(Path, Path, FileSystem) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Reset the manager to allow another snapshot to proceed
- completeSnapshot(HBaseProtos.SnapshotDescription, Path, Path, FileSystem) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Move the finished snapshot to its final, publicly visible directory - this marks the snapshot
as 'complete'.
- CompoundBloomFilter - Class in org.apache.hadoop.hbase.util
-
A Bloom filter implementation built on top of
ByteBloomFilter
,
encapsulating a set of fixed-size Bloom filters written out at the time of
HFile
generation into the data
block stream, and loaded on demand at query time.
- CompoundBloomFilter(DataInput, HFile.Reader) - Constructor for class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
De-serialization for compound Bloom filter metadata.
- CompoundBloomFilterBase - Class in org.apache.hadoop.hbase.util
-
- CompoundBloomFilterBase() - Constructor for class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- CompoundBloomFilterWriter - Class in org.apache.hadoop.hbase.util
-
Adds methods required for writing a compound Bloom filter to the data
section of an
HFile
to the
CompoundBloomFilter
class.
- CompoundBloomFilterWriter(int, float, int, int, boolean, RawComparator<byte[]>) - Constructor for class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- compressAlgo - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Filled when we read in the trailer.
- compressAlgo - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
The compression algorithm used.
- compression - Variable in class org.apache.hadoop.hbase.avro.generated.AFamilyDescriptor
-
- COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- Compression - Class in org.apache.hadoop.hbase.io.hfile
-
Compression related stuff.
- compression - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- compression - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- Compression.Algorithm - Enum in org.apache.hadoop.hbase.io.hfile
-
Compression algorithms.
- COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- COMPRESSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- compressionByName(String) - Static method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- compressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
Compression context to use reading.
- CompressionTest - Class in org.apache.hadoop.hbase.util
-
Compression validation test.
- CompressionTest() - Constructor for class org.apache.hadoop.hbase.util.CompressionTest
-
- compressKeyValues(DataOutputStream, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- compressKeyValues(DataOutputStream, ByteBuffer, boolean) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Compress KeyValues and write them to output buffer.
- compressKeyValues(DataOutputStream, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- compressKeyValues(DataOutputStream, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- compressKeyValues(DataOutputStream, ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- Compressor - Class in org.apache.hadoop.hbase.regionserver.wal
-
A set of static functions for running our custom WAL compression/decompression.
- Compressor() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.Compressor
-
- computeBitSize(long, double) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- computeFilename() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
This is a convenience method that computes a new filename with a given
using the current HLog file-number
- computeFilename(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
This is a convenience method that computes a new filename with a given
file-number.
- computeFoldableByteSize(long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Increases the given byte size of a Bloom filter until it can be folded by
the given factor.
- computeHDFSBlocksDistribution(Configuration, HTableDescriptor, String) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function to compute HDFS block distribution on demand
- computeHDFSBlocksDistribution(Configuration, HTableDescriptor, String, Path) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function to compute HDFS block distribution on demand
- computeHDFSBlocksDistribution(FileSystem, FileStatus, long, long) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Compute HDFS blocks distribution of a given file, or a portion of the file
- computeMaxKeys(long, double, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
The maximum number of keys we can put into a Bloom filter of a certain
size to get the given error rate, with the given number of hash functions.
- CONCURRENT_HASHMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentHashMap
- CONCURRENT_HASHMAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentHashMap.Entry
- CONCURRENT_HASHMAP_SEGMENT - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentHashMap.Segment
- CONCURRENT_SKIPLISTMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentSkipListMap
- CONCURRENT_SKIPLISTMAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentSkipListMap Entry
- conf - Variable in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- conf - Variable in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectable
-
- conf - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- conf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.Invocation
-
- conf - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- conf - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- conf - Variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- conf - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- CONF_SKIP_TMP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONFIG - 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.
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
Upon construction, this method will be called with the region
to be governed.
- configureGlobally(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
Sets the flag whether to use table name in metric names according to the
given configuration.
- configureIncrementalLoad(Job, HTable) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
-
Configure a MapReduce Job to perform an incremental load into the given
table.
- connect(HConnection) - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectable
-
- connect(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- connect(boolean) - Method in class org.apache.hadoop.hbase.client.ServerCallable
-
Connect to the server hosting region with row from tablename.
- connect() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
To repair region consistency, one must call connect() in order to repair
online state.
- connect(Configuration, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates a new connection to ZooKeeper, pulling settings and ensemble config
from the specified configuration object using methods from
ZKConfig
.
- connect(Configuration, String, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- connect(Configuration, String, Watcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- connection - Variable in class org.apache.hadoop.hbase.client.ServerCallable
-
- connection - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- CONNECTION_PROPERTIES - Static variable in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionKey
-
- connectionList - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- connections - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- ConnectionUtils - Class in org.apache.hadoop.hbase.client
-
- ConnectionUtils() - Constructor for class org.apache.hadoop.hbase.client.ConnectionUtils
-
- connectToPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
This method connects this cluster to another one and registers it
in this region server's replication znode
- Constants - Interface in org.apache.hadoop.hbase.rest
-
Common constants for org.apache.hadoop.hbase.rest
- ConstantSizeRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A
RegionSplitPolicy
implementation which splits a region
as soon as any of its store files exceeds a maximum configurable
size.
- ConstantSizeRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
- constrainHttpMethods(Context) - Static method in class org.apache.hadoop.hbase.util.HttpServerUtil
-
Add constraints to a Jetty Context to disallow undesirable Http methods.
- Constraint - Interface in org.apache.hadoop.hbase.constraint
-
Apply a
Constraint
(in traditional database terminology) to a HTable.
- ConstraintException - Exception in org.apache.hadoop.hbase.constraint
-
Exception that a user defined constraint throws on failure of a
Put
.
- ConstraintException() - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- ConstraintException(String) - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- ConstraintException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- ConstraintProcessor - Class in org.apache.hadoop.hbase.constraint
-
- ConstraintProcessor() - Constructor for class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
Create the constraint processor.
- Constraints - Class in org.apache.hadoop.hbase.constraint
-
Utilities for adding/removing constraints from a table.
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- constructMaster(Class<? extends HMaster>, Configuration) - Static method in class org.apache.hadoop.hbase.master.HMaster
-
Utility for constructing an instance of the passed HMaster class.
- constructRegionServer(Class<? extends HRegionServer>, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Utility for constructing an instance of the passed HRegionServer class.
- contains(Object) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- contains(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
Check to see if the passed file name is contained in any of the snapshots.
- contains(Object) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- contains(Object) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- contains(byte[], int, int, ByteBuffer) - Method in interface org.apache.hadoop.hbase.util.BloomFilter
-
Check if the specified key is contained in the bloom filter.
- contains(byte[], int, int, ByteBuffer) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- contains(byte[], int, int, byte[], int, int, Hash, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- contains(byte[], int, int, ByteBuffer) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- contains(Object) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- containsColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks for existence of the specified column.
- containsKey(Object) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- containsKey(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Checks whether there is a value in the map for the specified key.
- containsKey(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- containsKey(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- containsKeyInRegionsInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- containsKeyInRegionsInTransition(HRegionInfo) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- 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.
- containsRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
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.
- containsRow(byte[]) - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
Return true if the given row falls in this region.
- containsValue(Object) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- containsValue(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Checks whether this is a mapping which contains the specified value.
- containsValue(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- containsValue(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- CONTEXT_NAME - Static variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- controllerConnectionFailure(String, IOException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
The connection to the rest of the procedure group (member and coordinator) has been
broken/lost/failed.
- 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
- convertToBigInteger(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Returns the BigInteger represented by the byte array
- convertToByte(BigInteger, int) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Returns the bytes corresponding to the BigInteger
- convertToByte(BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Returns the bytes corresponding to the BigInteger
- convertToBytes(BigInteger[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Returns an array of bytes corresponding to an array of BigIntegers
- coordinator - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
- Coprocessor - Interface in org.apache.hadoop.hbase
-
Coprocess interface.
- Coprocessor.State - Enum in org.apache.hadoop.hbase
-
Lifecycle state of a given coprocessor instance.
- CoprocessorClassLoader - Class in org.apache.hadoop.hbase.util
-
ClassLoader used to load classes for Coprocessor instances.
- CoprocessorEnvironment - Interface in org.apache.hadoop.hbase
-
Coprocessor environment state.
- CoprocessorException - Exception in org.apache.hadoop.hbase.coprocessor
-
Thrown if a coprocessor encounters any exception.
- CoprocessorException() - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Default Constructor
- CoprocessorException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Constructor with a Class object and exception message.
- CoprocessorException(String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Constructs the exception and supplies a string as the message
- coprocessorExec(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
- coprocessorExec(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
- coprocessorExec(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- coprocessorExec(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- coprocessorExec(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- coprocessorExec(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- CoprocessorHConnection - Class in org.apache.hadoop.hbase.client
-
Connection to an HTable from within a Coprocessor.
- CoprocessorHost<E extends CoprocessorEnvironment> - Class in org.apache.hadoop.hbase.coprocessor
-
Provides the common setup framework and runtime services for coprocessor
invocation from HBase services.
- CoprocessorHost() - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- CoprocessorHost.Environment - Class in org.apache.hadoop.hbase.coprocessor
-
Encapsulation of the environment of each coprocessor
- CoprocessorHost.Environment(Coprocessor, int, int, Configuration) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Constructor
- CoprocessorProtocol - Interface in org.apache.hadoop.hbase.ipc
-
All custom RPC protocols to be exported by Coprocessors must extend this interface.
- coprocessorProxy(Class<T>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates and returns a proxy to the CoprocessorProtocol instance running in the
master.
- coprocessorProxy(Class<T>, byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates and returns a proxy to the CoprocessorProtocol instance running in the
region containing the specified row.
- coprocessorProxy(Class<T>, byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Creates and returns a proxy to the CoprocessorProtocol instance running in the
region containing the specified row.
- coprocessorProxy(Class<T>, byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- coprocessors - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Ordered set of loaded coprocessors with lock
- 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
- 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
- copyFromNext(BufferedDataBlockEncoder.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerState
-
- copyFromNext(BufferedDataBlockEncoder.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerState
-
- 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.
- CopyKeyDataBlockEncoder - Class in org.apache.hadoop.hbase.io.encoding
-
Just copy data, do not do any kind of compression.
- CopyKeyDataBlockEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- COPYONWRITE_ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for CopyOnWriteArrayList
- COPYONWRITE_ARRAYSET - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for CopyOnWriteArraySet
- copyQueuesFromRS(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
This methods copies all the hlogs queues from another region server
and returns them all sorted per peer cluster (appended with the dead
server's znode)
- copyQueuesFromRSUsingMulti(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
It "atomically" copies all the hlogs queues from another region server and returns them all
sorted per peer cluster (appended with the dead server's znode).
- CopyRecoveredEditsTask - Class in org.apache.hadoop.hbase.snapshot
-
Copy over each of the files in a region's recovered.edits directory to the region's snapshot
directory.
- CopyRecoveredEditsTask(HBaseProtos.SnapshotDescription, ForeignExceptionDispatcher, FileSystem, Path, Path) - Constructor for class org.apache.hadoop.hbase.snapshot.CopyRecoveredEditsTask
-
- 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
-
- copyWritable(Writable, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Copy one Writable to another.
- copyWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Copy one Writable to another.
- 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
-
- CorruptHFileException - Exception in org.apache.hadoop.hbase.io.hfile
-
This exception is thrown when attempts to read an HFile fail due to corruption or truncation
issues.
- count - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.ParallelResults
-
- count - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLog.Metric
-
- counter - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- countOfBytesInRemoteResults - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of bytes in Result objects from remote region servers
- countOfBytesInResults - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of bytes in Result objects from region servers
- countOfNSRE - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of NotServingRegionException caught
- countOfRegions - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of regions
- countOfRemoteRPCcalls - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of remote RPC calls
- countOfRemoteRPCRetries - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of remote RPC retries
- countOfRPCcalls - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of RPC calls
- countOfRPCRetries - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of RPC retries
- 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(UserGroupInformation) - Method in class org.apache.hadoop.hbase.client.UserProvider
-
- 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(BlockCacheColumnFamilySummary) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
Creates a new BlockCacheSummaryEntry
- create() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- create(Configuration, String, String, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create an HFileLink instance from table/region/family/hfile location
- create(Configuration, FileSystem, Path, HRegionInfo, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink
- create(Configuration, FileSystem, Path, String, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink
- create(HRegion, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
Create the RegionSplitPolicy configured for the given table.
- create(Configuration, CompressionContext) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEditCodec
-
Create and setup a
WALEditCodec
from the
Configuration
, if one has been
specified.
- create(UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.User
-
Wraps an underlying UserGroupInformation
instance.
- create(FileSystem, Path, FsPermission) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Create the specified file on the filesystem.
- create(FileSystem, Path, FsPermission, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Create the specified file on the filesystem.
- create() - Method in class org.apache.hadoop.hbase.util.RetryCounterFactory
-
- create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
NONSEQUENTIAL create is idempotent operation.
- createAndFailSilent(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node, iff the node does not exist.
- createAndFailSilent(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node containing specified data, iff the node does not exist.
- createAndFailSilent(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- createAndPrepare(T, ObserverContext<T>) - Static method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
Instantiates a new ObserverContext instance if the passed reference is
null
and sets the environment in the new or existing instance.
- createAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node with the specified data and watches it.
- createAnother() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Creates another similar Bloom filter.
- createBloomKey(byte[], int, int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
Create a key for a row-column Bloom filter.
- createBloomKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Create a key for a row-column Bloom filter.
- createBloomKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
Prepare an ordered pair of row and qualifier to be compared using
KeyValue.KeyComparator.
- createBySize(int, double, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Creates a Bloom filter of the given size.
- 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
- createComparator(String) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- 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.hfile.Compression.Algorithm
-
- createConfigurationSubset() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- 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
-
- createConnection(HBaseClient.ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
Creates a connection.
- createConnection(HBaseClient.ConnectionId) - Method in class org.apache.hadoop.hbase.ipc.SecureClient
-
Creates a SecureConnection.
- createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
-
- createDeleteBloomAtWrite(Configuration, CacheConfig, int, HFile.Writer) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Creates a new Delete Family Bloom filter at the time of
StoreFile
writing.
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Called when a new Coprocessor class is loaded
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
- createEphemeralNodeAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Set the specified znode to be an ephemeral node carrying the specified
data.
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FilterBase
-
Given the filter's arguments it constructs the filter
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
-
- createFirstDeleteFamilyOnRow(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Create a Delete Family KeyValue for the specified row and family that would
be smaller than all other possible Delete Family KeyValues that have the
same row and family.
- createFirstOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Create a KeyValue that is smaller than all other possible KeyValues
for the given row.
- createFirstOnRow(byte[], int, short) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Create a KeyValue that is smaller than all other possible KeyValues
for the given row.
- createFirstOnRow(byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Creates a KeyValue that is smaller than all other KeyValues that
are older than the passed timestamp.
- createFirstOnRow(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Create a KeyValue for the specified row, family and qualifier that would be
smaller than all other possible KeyValues that have the same row,family,qualifier.
- createFirstOnRow(byte[], byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- createFirstOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Create a KeyValue for the specified row, family and qualifier that would be
smaller than all other possible KeyValues that have the same row,
family, qualifier.
- createFirstOnRowColTS(long) - Method in class org.apache.hadoop.hbase.KeyValue
-
Creates the first KV with the row/family/qualifier of this KV and the
given timestamp.
- createForName(String) - Static method in class org.apache.hadoop.hbase.util.Classes
-
This method is almost the same as #createWritableForName, except
that this one doesn't expect the filter class to extends Configurable.
- createFromFileInfo(HFile.FileInfo, DataBlockEncoding) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- createFromHFileLink(Configuration, FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink starting from a hfileLink name
- createFromMeta(DataInput, HFile.Reader) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Instantiates the correct Bloom filter class based on the version provided
in the meta block data.
- createFromStoreFilePath(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
Construct a BlockCacheSummaryEntry from a full StoreFile Path
The path is expected to be in the format of...
- createGeneralBloomAtWrite(Configuration, CacheConfig, StoreFile.BloomType, int, HFile.Writer) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Creates a new general (Row or RowCol) Bloom filter at the time of
StoreFile
writing.
- 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.
- createHDFSRegionDir(Configuration, HRegionInfo, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Creates, flushes, and closes a new region.
- createHFileCorruptionChecker(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- createHFileLinkName(HRegionInfo, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink name
- createHFileLinkName(String, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink name
- createHostAndPortStr(String, int) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, HLog, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, HLog, boolean, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, HLog) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- createHTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
- createHTableInterface(Configuration, byte[]) - Method in class org.apache.hadoop.hbase.client.HTableFactory
-
- createHTableInterface(Configuration, byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
-
Creates a new HTableInterface.
- createIdentifier() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- createInetSocketAddressFromHostAndPortStr(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- createKey(String) - Static method in class org.apache.hadoop.hbase.util.Keying
-
Makes a key out of passed URI for use as row name or column qualifier.
- createKeyOnly(boolean) - Method in class org.apache.hadoop.hbase.KeyValue
-
Creates a new KeyValue that only contains the key portion (the value is
set to be null).
- createKeyValueFromKey(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- createKeyValueFromKey(ByteBuffer) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- createKeyValueFromKey(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- createLastOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Creates a KeyValue that is last on the specified row id.
- createLastOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Create a KeyValue for the specified row, family and qualifier that would be
larger than or equal to all other possible KeyValues that have the same
row, family, qualifier.
- createLastOnRowCol() - Method in class org.apache.hadoop.hbase.KeyValue
-
- createLease(String, LeaseListener) - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Obtain a lease
- createLogSplitter(Configuration, Path, Path, Path, FileSystem) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
Create a new HLogSplitter using the given Configuration
and the
hbase.hlog.splitter.impl
property to derived the instance
class to use.
- createMasterThread(Configuration, Class<? extends HMaster>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
- createMetrics(Class<?>[]) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
Generate metrics entries for all the methods defined in the list of
interfaces.
- createMetrics(Class<?>[], boolean) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
Generate metrics entries for all the methods defined in the list of
interfaces.
- createMetrics(Class<?>[], boolean, String[]) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
Generate metrics entries for all the methods defined in the list of
interfaces.
- createNewFileOnFileSystem(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.HBaseFileSystem
-
Creates the file.
- createNodeClosing(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates a new unassigned node in the CLOSING state for the specified
region.
- createNodeIfNotExistsAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified znode to be a persistent node carrying the specified
data.
- createNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates a new unassigned node in the OFFLINE state for the specified region.
- createNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, EventHandler.EventType) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
- createNonRecursive(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
The org.apache.hadoop.fs.FilterFileSystem does not yet support
createNonRecursive.
- createOrForceNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates or force updates an unassigned node to the OFFLINE state for the
specified region.
- createOrForceNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, boolean, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates or force updates an unassigned node to the OFFLINE state for the
specified region.
- createOutputStream(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
A helper method to create HFile output streams in constructors
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.ReusableStreamGzipCodec
-
- createPassword(AuthenticationTokenIdentifier) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- createPath(String, String, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create an HFileLink relative path for the table/region/family/hfile location
- createPathOnFileSystem(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.HBaseFileSystem
-
Creates a path on the file system.
- createPathWithPermsOnFileSystem(FileSystem, Path, FsPermission, boolean) - Static method in class org.apache.hadoop.hbase.HBaseFileSystem
-
Creates the specified file with the given permission.
- createPool() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- createProtobufOutput() - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
-
- createReader(FileSystem, Path, CacheConfig) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- createReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- createReaderWithEncoding(FileSystem, Path, CacheConfig, DataBlockEncoding) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- createReaderWithEncoding(FileSystem, Path, FSDataInputStream, FSDataInputStream, long, CacheConfig, DataBlockEncoding, boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- 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
-
- createRegionLoad(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createRegionName(byte[], byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionName(byte[], byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionName(byte[], byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionName(byte[], byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
Make a region name of passed parameters.
- createRegionName(byte[], byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
Make a region name of passed parameters.
- createRegionName(byte[], byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
Make a region name of passed parameters.
- createRegions(Configuration, Path, HTableDescriptor, HRegionInfo[]) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegions(Configuration, Path, HTableDescriptor, HRegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegionServerThread(Configuration, Class<? extends HRegionServer>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
- createRPCStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- createSecretKey(byte[]) - Static method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- createSecretManager() - Method in class org.apache.hadoop.hbase.ipc.SecureRpcEngine.Server
-
- createSeeker(RawComparator<byte[]>, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- createSeeker(RawComparator<byte[]>, boolean) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Create a HFileBlock seeker which find KeyValues within a block.
- createSeeker(RawComparator<byte[]>, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- createSeeker(RawComparator<byte[]>, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- createSeeker(RawComparator<byte[]>, boolean) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- createSetData(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Set data into node creating node if it doesn't yet exist.
- createStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- 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.replication.VerifyReplication
-
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.
- createSubprocedure(String, byte[]) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
This is separated from execution so that we can detect and handle the case where the
subprocedure is invalid and inactionable due to bad info (like DISABLED snapshot type being
sent here)
- createTable(ATableDescriptor) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- createTable(ATableDescriptor, Callback<Void>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- createTable(ATableDescriptor) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- 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, byte[][]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Creates a new table asynchronously.
- createTable(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createTable(HTableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Create a table using the given table definition.
- createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
Creates a new table.
- createTable(ByteBuffer, List<ColumnDescriptor>, AsyncMethodCallback<Hbase.AsyncClient.createTable_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- createTable(ByteBuffer, List<ColumnDescriptor>, AsyncMethodCallback<Hbase.AsyncClient.createTable_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- createTable(ByteBuffer, List<ColumnDescriptor>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Create a table with the specified column families.
- createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- 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.
- createTableDescriptor(HTableDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Create new HTableDescriptor in HDFS.
- createTableDescriptor(HTableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create new HTableDescriptor in HDFS.
- createTableDescriptor(FileSystem, Path, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create new HTableDescriptor in HDFS.
- createTableDescriptor(FileSystem, Path, HTableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create new HTableDescriptor in HDFS.
- createTableDescriptorForTableDirectory(FileSystem, Path, HTableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create a new HTableDescriptor in HDFS in the specified table directory.
- CreateTableHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handler to create a table.
- CreateTableHandler(Server, MasterFileSystem, ServerManager, HTableDescriptor, Configuration, HRegionInfo[], CatalogTracker, AssignmentManager) - Constructor for class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- 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
- createUnknown() - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
Creates an instance corresponding to an unknown table and column family.
- createUserForTesting(Configuration, String, String[]) - Static method in class org.apache.hadoop.hbase.security.User
-
Generates a new User
instance specifically for use in test code.
- createUserForTesting(Configuration, String, String[]) - Static method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- createWithParents(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node and all parent nodes required for it to exist.
- createWithParents(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node and all parent nodes required for it to exist.
- createWritableForName(String) - Static method in class org.apache.hadoop.hbase.util.Classes
-
Used to dynamically load a filter class, and create a Writable filter.
- createWriter(FileSystem, Path, FSDataOutputStream, int, Compression.Algorithm, HFileDataBlockEncoder, KeyValue.KeyComparator, ChecksumType, int, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- createWriter(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Get a writer for the WAL.
- createWriter(FileSystem, Configuration, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogFileSystem
-
Creates writer for the given path.
- createWriter(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- createWriterInstance(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
This method allows subclasses to inject different writers without having to
extend other methods like rollWriter().
- createWriterInTmp(int, Compression.Algorithm, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- CREATIONTIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- CREATOR_ALL_AND_WORLD_READABLE - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- CRLF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- csToACS(ClusterStatus) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- CurCall - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
This is set to Call object before Handler invokes an RPC and reset
after the call returns.
- currBlock - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.AbstractScannerV1
-
- current - Variable in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- current() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- current() - Method in interface org.apache.hadoop.hbase.codec.Decoder
-
- CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.ipc.SecureServer
-
- currentCompactedKVs - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
the completed count of key values in currently running compaction
- CURRENTCOMPACTEDKVS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- currentRegion - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- currentTimeMillis() - Method in class org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
-
Returns the currentTimeMillis.
- currentTimeMillis() - Method in interface org.apache.hadoop.hbase.util.EnvironmentEdge
-
Returns the currentTimeMillis.
- currentTimeMillis() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
- currentTimeMillis() - Method in class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
-
Returns the currentTimeMillis.
- currentTimeMillis() - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- currKeyLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- currMemstoreTS - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- currMemstoreTSLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- currValueLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- D - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'D'
- DaemonThreadFactory - Class in org.apache.hadoop.hbase
-
Thread factory that creates daemon threads
- DaemonThreadFactory(String) - Constructor for class org.apache.hadoop.hbase.DaemonThreadFactory
-
- DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- DATA_BLOCK_ENCODING - Static variable in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Type of encoding used for data blocks in HFile.
- DATA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- 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
-
- DataBlockEncoder - Interface in org.apache.hadoop.hbase.io.encoding
-
Encoding of KeyValue.
- dataBlockEncoder - Variable in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
- dataBlockEncoder - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
What kind of data block encoding should be used while reading, writing,
and handling cache.
- dataBlockEncoder - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- DataBlockEncoder.EncodedSeeker - Interface in org.apache.hadoop.hbase.io.encoding
-
An interface which enable to seek while underlying data is encoded.
- DataBlockEncoding - Enum in org.apache.hadoop.hbase.io.encoding
-
Provide access to all data block encoding algorithms.
- dataBlockIndexReader - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Data block index reader keeping the root data index in memory
- dataBlockReadCnt - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
- DEADNODES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- DeadServer - Class in org.apache.hadoop.hbase.master
-
Class to hold dead servers list and utility querying dead server list.
- DeadServer() - Constructor for class org.apache.hadoop.hbase.master.DeadServer
-
- deadServerNames - Variable in class org.apache.hadoop.hbase.avro.generated.AClusterStatus
-
- deadServers - Variable in class org.apache.hadoop.hbase.avro.generated.AClusterStatus
-
- deadServers - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- deadServers - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- 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
- DebugPrint - Class in org.apache.hadoop.hbase.regionserver
-
- DebugPrint() - Constructor for class org.apache.hadoop.hbase.regionserver.DebugPrint
-
- DECLARINGCLASS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- 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.
- decode(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- 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.
- decodeFileToFile(String, String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Reads infile and decodes it to outfile.
- decodeFromFile(String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Convenience method for reading a base64-encoded file and decoding it.
- Decoder - Interface in org.apache.hadoop.hbase.codec
-
An interface for iterating through a sequence of KeyValues.
- decodeRemoteException(RemoteException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
-
Deprecated.
Use RemoteException.unwrapRemoteException()
instead.
In fact we should look into deprecating this whole class - St.Ack 2010929
- 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.
- decorateMasterConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
This method modifies the master's configuration in order to inject
replication-related features
- decrease(long) - Method in class org.apache.hadoop.hbase.util.SizeBasedThrottler
-
Decreases value of internal counter.
- decrement() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Decrement the current version count
- decRpcCount() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.MemStore
-
- DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.Store
-
- deepCopy() - Method in class org.apache.hadoop.hbase.KeyValue
-
Creates a deep copy of this KeyValue, re-allocating the buffer.
- deepCopy() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- deepCopy() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- deepCopy() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- deepCopy() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- deepCopy() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to use a block cache or not.
- DEFAULT_BLOCKING_STOREFILE_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.Store
-
- 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.io.hfile.HFile
-
Default block size for an HFile.
- DEFAULT_BLOCKSIZE_SMALL - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether or not to use bloomfilters.
- DEFAULT_BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
The number of bytes per checksum.
- 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_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_CACHE_DATA_ON_READ - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- 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_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_CACHE_FLUSH_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Default interval for the memstore flush
- 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_CACHE_INDEXES_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_CHECKSUM_TYPE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
- 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_COMPRESSED_CACHE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default compression type.
- DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Default compression name: none.
- DEFAULT_COMPRESSION_ALGORITHM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Default compression: none.
- DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default data block encoding algorithm.
- DEFAULT_ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default value of the flag that enables data block encoding on disk, as
opposed to encoding in cache only.
- DEFAULT_END_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.rest.RowSpec
-
- 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_EVICT_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- 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_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_RPC_MAXATTEMPTS - 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_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_REGIONSERVER_LEASE_PERIOD - 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_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_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for preventing deleted from being collected immediately.
- DEFAULT_KEYVALUE_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Strings
-
- DEFAULT_LISTEN_PORT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- DEFAULT_LISTEN_PORT - Static variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
-
- DEFAULT_LISTEN_PORT - Static variable in class org.apache.hadoop.hbase.thrift2.ThriftServer
-
- DEFAULT_LOCAL_DIR - Static variable in class org.apache.hadoop.hbase.util.ClassLoaderBase
-
- 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_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_MAX_PUT_OUTPUT - Static variable in class org.apache.hadoop.hbase.client.MultiPut
-
Deprecated.
- DEFAULT_MAX_QUEUED_REQUESTS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- DEFAULT_MAX_RESUBMIT - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- DEFAULT_MAX_WAIT_TIME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
By default, wait 60 seconds for a snapshot to complete
- DEFAULT_MAX_WORKER_THREADS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- 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_MIN_WORKER_THREADS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
This default core pool size should be enough for many test scenarios.
- DEFAULT_PATH - Static variable in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.TotalOrderPartitioner
-
- 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_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default region server interface class name.
- DEFAULT_REGIONSERVER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
default port for region server web api
- 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_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Strings
-
- DEFAULT_SIZE_RESERVATION_BLOCK - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default size of a reservation block
- DEFAULT_SLEEP_BEFORE_RERUN - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
- DEFAULT_SLOW_RESPONSE_NANO_SEC - Static variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- DEFAULT_START_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.rest.RowSpec
-
- 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_TIMEOUT - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default time to live of cell contents.
- DEFAULT_UNASSIGNED_TIMEOUT - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- 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_RETRIES - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- 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
- DefaultEnvironmentEdge - Class in org.apache.hadoop.hbase.util
-
Default implementation of an environment edge.
- DefaultEnvironmentEdge() - Constructor for class org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
-
- DefaultLoadBalancer - Class in org.apache.hadoop.hbase.master
-
Makes decisions about the placement and movement of Regions across
RegionServers.
- DefaultLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.DefaultLoadBalancer
-
- defaultPool(String, int) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Default thread pool for the procedure
- defaultPool(String, int, long) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Default thread pool for the procedure
- defaultPool(String, int) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Default thread pool for the procedure
- defaultPool(String, int, long) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Default thread pool for the procedure
- DEFERRED_LOG_FLUSH - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by HBase Shell interface to access this metadata
attribute which denotes if the deferred log flush option is enabled
- deferredLogFlush - Variable in class org.apache.hadoop.hbase.avro.generated.ATableDescriptor
-
- Delayable - Interface in org.apache.hadoop.hbase.ipc
-
A call whose response can be delayed by the server.
- delayResponse - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- delayReturnValue - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- delete(ByteBuffer, ADelete) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- delete(ByteBuffer, ADelete, Callback<Void>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- delete(ByteBuffer, ADelete) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- Delete - Class in org.apache.hadoop.hbase.client
-
Used to perform Delete operations on a single row.
- Delete() - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Constructor for Writable.
- 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[], long, RowLock) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
- 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(Scan, byte, Long, int) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
-
- delete(Scan, byte, Long, int) - Method in interface org.apache.hadoop.hbase.coprocessor.example.BulkDeleteProtocol
-
- delete(byte[], Delete) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Deletes all the KeyValues that match those found in the Delete object,
if their ts <= to the Delete.
- delete(byte[], List<Delete>) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Put an array of deletes into the specified region
- delete(Delete, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- delete(Delete, Integer, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
row locks (lockId) held outside the extent of the operation are deprecated.
- delete(byte[], Delete) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- delete(byte[], List<Delete>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- delete(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
Adds a value to the memstore
- 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
-
- delete(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
- delete(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- delete(UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
-
- delete(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Calls fs.delete() and returns the value returned by the fs.delete()
- delete(String, int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
delete is an idempotent operation.
- DELETE_FAMILY_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Delete Family Count in FileInfo
- deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAll_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAll_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Delete all cells that match the passed row and column.
- deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- deleteAllConnections(boolean) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
- deleteAllConnections() - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- deleteAllNodes(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes all unassigned nodes regardless of their state.
- deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAllRow_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAllRow_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Completely delete the row's cells.
- deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAllRowTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAllRowTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Completely delete the row's cells marked with a timestamp
equal-to or older than the passed timestamp.
- deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAllTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAllTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Delete all cells that match the passed row and column and whose
timestamp is equal-to or older than the passed timestamp.
- deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- deleteCachedRegionLocation(HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deletes cached locations for the specific region.
- deleteChildrenRecursively(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete all the children of the specified node but not the node itself.
- deleteClosedNode(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the CLOSED state for the
specified region.
- deleteClosingNode(ZooKeeperWatcher, HRegionInfo) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the CLOSING state for the
specified region.
- deleteClosingOrClosedNode(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- 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(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete a column from a table.
- deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete a column from a table.
- deleteColumn(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Deletes a column from the specified table.
- deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Delete column of a table
- deleteColumn(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Delete a column from an existing 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, boolean) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
- deleteConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- deleteDirectory(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Delete if exists.
- deleteDirFromFileSystem(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.HBaseFileSystem
-
Deletes a directory.
- deleteFamily(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- deleteFamily(ByteBuffer, ByteBuffer, Callback<Void>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- deleteFamily(ByteBuffer, ByteBuffer) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- 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.
- deleteFamilyBloomFilter - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- deleteFamilyFromFS(HRegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- deleteFileFromFileSystem(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.HBaseFileSystem
-
Deletes a file.
- deleteFromHBase(Delete) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- deleteFromMetaTable(CatalogTracker, List<Delete>) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
-
Delete the passed deletes
from the .META.
table.
- deleteFromThrift(TDelete) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- deleteMultiple(ByteBuffer, List<TDelete>, AsyncMethodCallback<THBaseService.AsyncClient.deleteMultiple_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- deleteMultiple(ByteBuffer, List<TDelete>, AsyncMethodCallback<THBaseService.AsyncClient.deleteMultiple_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- deleteMultiple(ByteBuffer, List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- deleteMultiple(ByteBuffer, List<TDelete>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Bulk commit a List of TDeletes to the table.
- deleteMultiple(ByteBuffer, List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- deleteNode(ZooKeeperWatcher, String, EventHandler.EventType) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the specified state for the
specified region.
- deleteNode(ZooKeeperWatcher, String, EventHandler.EventType, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the specified state for the
specified region.
- deleteNode(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete the specified node.
- deleteNode(ZooKeeperWatcher, String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete the specified node with the specified version.
- deleteNodeAndOfflineRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Delete znode of region in transition if table is disabling/disabled and offline the region.
- deleteNodeFailSilent(ZooKeeperWatcher, HRegionInfo) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Delete the assignment node regardless of its current state.
- deleteNodeFailSilent(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Deletes the specified node.
- deleteNodeFailSilent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- deleteNodeRecursively(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete the specified node and all of it's children.
- deleteOfflineNode(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the OFFLINE state for the
specified region.
- deleteOpenedNode(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the OPENED state for the
specified region.
- deleteOwnRSZNode() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Delete this cluster's queues
- deleteReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Delete this file
- deleteRegion(CatalogTracker, HRegionInfo) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
-
Deletes the specified region from META.
- deleteRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- deleteRegion(FileSystem, Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deletes all the files for a HRegion
- deleteRegions(CatalogTracker, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
-
Deletes the specified regions from META.
- deleteRootLocation(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.catalog.RootLocationEditor
-
Deletes the location of -ROOT-
in ZooKeeper.
- deleteRsQueues(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Recursive deletion of all znodes in specified rs' znode
- deletes - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
list of TDeletes to delete
- deletesFromHBase(List<Delete>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- deletesFromThrift(List<TDelete>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Converts multiple
TDelete
s (Thrift) into a list of
Delete
s (HBase).
- deleteShutdownHook(Runnable) - Static method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- deleteSingle(ByteBuffer, TDelete, AsyncMethodCallback<THBaseService.AsyncClient.deleteSingle_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- deleteSingle(ByteBuffer, TDelete, AsyncMethodCallback<THBaseService.AsyncClient.deleteSingle_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- deleteSingle - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
the TDelete to execute if the check succeeds
- deleteSingle(ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- deleteSingle - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
the TDelete to delete
- deleteSingle(ByteBuffer, TDelete) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Deletes as specified by the TDelete.
- deleteSingle(TDelete) - Static method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- deleteSingle(ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- 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.
- deleteSnapshot(HSnapshotDescription) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
- deleteSnapshot(HSnapshotDescription) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Execute Delete Snapshot operation.
- deleteSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Delete the specified snapshot
- deleteSource(String, boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Delete a complete queue of hlogs
- deleteStaleConnection(HConnection) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Delete stale connection information for the instance specified by configuration.
- deleteTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- deleteTable(ByteBuffer, Callback<Void>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- deleteTable(ByteBuffer) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- deleteTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deletes a table.
- deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deletes a table.
- deleteTable(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Deletes a table
- deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- deleteTable(byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Delete 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.
- deleteTable(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.deleteTable_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- deleteTable(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.deleteTable_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- deleteTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- deleteTable(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Deletes a table
- deleteTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- deleteTableDescriptorIfExists(String, Configuration) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Deletes a table's directory from the file system if exists.
- DeleteTableHandler - Class in org.apache.hadoop.hbase.master.handler
-
- DeleteTableHandler(byte[], Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- 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.
- DeleteTracker - Interface in org.apache.hadoop.hbase.regionserver
-
This interface is used for the tracking and enforcement of Deletes
during the course of a Get or Scan operation.
- DeleteTracker.DeleteCompare - Enum in org.apache.hadoop.hbase.regionserver
-
Return codes for comparison of two Deletes.
- DeleteTracker.DeleteResult - Enum in org.apache.hadoop.hbase.regionserver
-
Returns codes for delete result.
- deleteType - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- DelimitedKeyPrefixRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A custom RegionSplitPolicy implementing a SplitPolicy that groups
rows by a prefix of the row-key with a delimiter.
- DelimitedKeyPrefixRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
- DELIMITER - Static variable in class org.apache.hadoop.hbase.HRegionInfo
-
delimiter used between portions of a region name
- DELIMITER - Static variable in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
delimiter used between portions of a region name
- DELIMITER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
- 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() - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Should only be used for writable
- DependentColumnFilter(byte[], byte[], boolean, CompareFilter.CompareOp, WritableByteArrayComparable) - 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.
- descendingIterator() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- descendingSet() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- describeFamily(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- describeFamily(ByteBuffer, ByteBuffer, Callback<AFamilyDescriptor>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- describeFamily(ByteBuffer, ByteBuffer) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- describeQuantity(Object) - Static method in class org.apache.hadoop.hbase.util.Objects
-
Attempts to construct a text description of the given object, by
introspecting known classes and building a description of size.
- describeTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- describeTable(ByteBuffer, Callback<ATableDescriptor>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- describeTable(ByteBuffer) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- description - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
-
- 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.
- deserialize(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.hfile.CacheableDeserializer
-
Returns the deserialized object.
- deserializeRegionInfo(DataInput) - Method in class org.apache.hadoop.hbase.client.HTable
-
Read from in
and deserialize the regions information.
- destroy() - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
-
- destroyDirectByteBuffer(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
DirectByteBuffers are garbage collected by using a phantom reference and a
reference queue.
- detail(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- DiffKeyDeltaEncoder - Class in org.apache.hadoop.hbase.io.encoding
-
Compress using:
- store size of common prefix
- save column family once, it is same within HFile
- use integer compression for key, value and prefix (7-bit encoding)
- use bits to avoid duplication key length, value length
and type if it same as previous
- store in 3 bits length of timestamp field
- allow diff in timestamp instead of actual value
Format:
- 1 byte: flag
- 1-5 bytes: key length (only if FLAG_SAME_KEY_LENGTH is not set in flag)
- 1-5 bytes: value length (only if FLAG_SAME_VALUE_LENGTH is not set in flag)
- 1-5 bytes: prefix length
- ...
- DiffKeyDeltaEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- DiffKeyDeltaEncoder.DiffCompressionState - Class in org.apache.hadoop.hbase.io.encoding
-
- DiffKeyDeltaEncoder.DiffCompressionState() - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffCompressionState
-
- DiffKeyDeltaEncoder.DiffSeekerState - Class in org.apache.hadoop.hbase.io.encoding
-
- DiffKeyDeltaEncoder.DiffSeekerState() - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerState
-
- diffMetrics(Map<String, Long>, Map<String, Long>) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- DirectMemoryUtils - Class in org.apache.hadoop.hbase.util
-
- DirectMemoryUtils() - Constructor for class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
- disable(HTableDescriptor) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Turn off processing constraints for a given table, even if constraints have
been turned on or added.
- disable() - Static method in class org.apache.hadoop.hbase.regionserver.DebugPrint
-
- disableConstraint(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
- DISABLED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- DisabledRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
- DisabledRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
-
- DisabledTableSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
-
Take a snapshot of a disabled table.
- DisabledTableSnapshotHandler(HBaseProtos.SnapshotDescription, MasterServices, MasterMetrics) - Constructor for class org.apache.hadoop.hbase.master.snapshot.DisabledTableSnapshotHandler
-
- 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.
- disablePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Disable replication to the peer
- disableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- disableTable(ByteBuffer, Callback<Void>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- disableTable(ByteBuffer) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- disableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Disable table and wait on completion.
- disableTable(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Take table offline
- disableTable(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- disableTable(byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Disable an existing table
- disableTable(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.disableTable_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- disableTable(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.disableTable_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- disableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- disableTable(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Disables a table (takes it off-line) If it is being served, the master
will tell the servers to stop serving it.
- disableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- disableTableAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTableAsync(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Starts the disable of a table.
- DisableTableHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handler to run disable of a table.
- DisableTableHandler(Server, byte[], CatalogTracker, AssignmentManager, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.DisableTableHandler
-
- 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
- diskToCacheFormat(HFileBlock, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Converts a block from the on-disk format to the in-cache format.
- diskToCacheFormat(HFileBlock, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- diskToCacheFormat(HFileBlock, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- dispose() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Release resources used by wrapped saslClient
- divideForAvg(BigDecimal, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- divideForAvg(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- divideForAvg(S, Long) - Method in interface org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
used for computing average of data values.
- 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, WritableByteArrayComparable, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- doCompressData() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Do the compression.
- doesIncludeMemstoreTS() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.master.MasterDumpServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.master.MasterStatusServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.regionserver.RSDumpServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.regionserver.RSStatusServlet
-
- doLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the logical value indicating whether on-demand CF loading should be allowed.
- doMain(String[]) - Static method in class org.apache.hadoop.hbase.avro.AvroServer
-
- doMain(String[]) - Method in class org.apache.hadoop.hbase.util.ServerCommandLine
-
Parse and run the given command line.
- domainNamePointerToHostName(String) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Given a PTR string generated via reverse DNS lookup, return everything
except the trailing period.
- doMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- done() - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
- done() - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
Done when there are no more columns to match against.
- done() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
We can never know a-priori if we are done, so always return false.
- doneBulkLoad(byte[], String) - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener
-
Called after a successful HFile load
- doneWithColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
This method is used to inform the column tracker that we are done with
this column.
- 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
-
- DONT_BREAK_LINES - Static variable in class org.apache.hadoop.hbase.util.Base64
-
Don't break lines when encoding (violates strict Base64 specification)
- DONT_FILL_HEADER - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- doRealSeek(KeyValueScanner, KeyValue, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- 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.
- doSmokeTest(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
-
- doStaticMain(String[]) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
Call this from the concrete tool class's main function.
- DoubleBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
DoubleBlockCache is an abstraction layer that combines two caches, the
smaller onHeapCache and the larger offHeapCache.
- DoubleBlockCache(long, long, long, long, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
Default constructor.
- DoubleOutputStream - Class in org.apache.hadoop.hbase.io
-
An output stream that writes to two streams on each operation.
- DoubleOutputStream(OutputStream, OutputStream) - Constructor for class org.apache.hadoop.hbase.io.DoubleOutputStream
-
- doUpdates(MetricsContext) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
Push the metrics to the monitoring subsystem on doUpdate() call.
- doUpdates(MetricsContext) - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
-
Since this object is a registered updater, this method will be called
periodically, e.g.
- doUpdates(MetricsContext) - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerDynamicMetrics
-
Push the metrics to the monitoring subsystem on doUpdate() call.
- doUpdates(MetricsContext) - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
Since this object is a registered updater, this method will be called
periodically, e.g.
- doUpdates(MetricsContext) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkMetrics
-
- doUpdates(MetricsContext) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceMetrics
-
- doUpdates(MetricsContext) - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
Since this object is a registered updater, this method will be called
periodically, e.g.
- doUpdates(MetricsContext) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
Push the metrics to the monitoring subsystem on doUpdate() call.
- doWork() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
The "main function" of the tool
- doWrite(HRegionInfo, HLogKey, WALEdit, HTableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- DrainingServerTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracks the list of draining region servers via ZK.
- DrainingServerTracker(ZooKeeperWatcher, Abortable, ServerManager) - Constructor for class org.apache.hadoop.hbase.zookeeper.DrainingServerTracker
-
- drainingZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- drainTo(Collection<? super Runnable>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- drainTo(Collection<? super Runnable>, int) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- 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
- dump(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- dumpAsText(PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- dumpExecutors(ExecutorService, PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- dumpOverlapProblems(Multimap<byte[], HBaseFsck.HbckInfo>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- dumpQueue() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- dumps - Variable in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
- dumpSidelinedRegions(Map<Path, HBaseFsck.HbckInfo>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- dumpTailOfLogs(PrintWriter, long) - Static method in class org.apache.hadoop.hbase.monitoring.LogMonitoring
-
- dumpTo(Writer, String) - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorStatus
-
Dump a textual representation of the executor's status
to the given writer.
- dumpTo(PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
-
Dump the contents of the buffer to the given stream.
- dumpToFile(String) - Static method in class org.apache.hadoop.hbase.regionserver.DebugPrint
-
- dumpVersionInfo(PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- Durability - Enum in org.apache.hadoop.hbase.client
-
Enum describing the durability guarantees for
Mutation
Note that the items must be sorted in order of increasing durability
- durability - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- durability - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- DynamicClassLoader - Class in org.apache.hadoop.hbase.util
-
This is a class loader that can load classes dynamically from new
jar files under a configured folder.
- DynamicClassLoader(Configuration, ClassLoader) - Constructor for class org.apache.hadoop.hbase.util.DynamicClassLoader
-
Creates a DynamicClassLoader that can load classes dynamically
from jar files under a specific folder.
- FAILED_SERVER_EXPIRY_DEFAULT - Static variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- FAILED_SERVER_EXPIRY_KEY - Static variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- failedBulkLoad(byte[], String) - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.BulkLoadListener
-
Called after a failed HFile load
- FailedLogCloseException - Exception in org.apache.hadoop.hbase.regionserver.wal
-
Thrown when we fail close of the write-ahead-log file.
- FailedLogCloseException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
-
- FailedLogCloseException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.FailedLogCloseException
-
- failedServers - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- failureSleep - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- families - Variable in class org.apache.hadoop.hbase.avro.generated.ATableDescriptor
-
- family - Variable in class org.apache.hadoop.hbase.avro.generated.AColumn
-
- family - Variable in class org.apache.hadoop.hbase.avro.generated.AColumnValue
-
- family - Variable in class org.apache.hadoop.hbase.avro.generated.AResultEntry
-
- FAMILY - Static variable in interface org.apache.hadoop.hbase.coprocessor.example.BulkDeleteProtocol.DeleteType
-
Delete full family(s).
- family - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
column name
- family - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- family - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- family - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- family - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
column family to check
- family - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
column family to check
- FAMILY_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Size of the family length field in bytes
- FamilyFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter based on the column family.
- FamilyFilter() - Constructor for class org.apache.hadoop.hbase.filter.FamilyFilter
-
Writable constructor, do not use.
- FamilyFilter(CompareFilter.CompareOp, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.FamilyFilter
-
Constructor.
- familyMap - Variable in class org.apache.hadoop.hbase.client.Mutation
-
- familySet() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the keys in the familyMap
- familySet() - Method in class org.apache.hadoop.hbase.client.Increment
-
Method for retrieving the keys in the familyMap
- FastDiffDeltaEncoder - Class in org.apache.hadoop.hbase.io.encoding
-
- FastDiffDeltaEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- FastDiffDeltaEncoder.FastDiffSeekerState - Class in org.apache.hadoop.hbase.io.encoding
-
- FastDiffDeltaEncoder.FastDiffSeekerState() - Constructor for class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerState
-
- fieldForId(int) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- fieldForId(int) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- fieldForId(int) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- fieldForId(int) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- fieldForId(int) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- fieldForId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- FILE_SYSTEM_VERSION - Static variable in class org.apache.hadoop.hbase.HConstants
-
Current version of file system.
- FileCleanerDelegate - Interface in org.apache.hadoop.hbase.master.cleaner
-
General interface for cleaning files from a folder (generally an archive or
backup folder).
- fileInfo - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- fileInfo - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
A "file info" block: a key-value map of file-wide metadata.
- FileLink - Class in org.apache.hadoop.hbase.io
-
The FileLink is a sort of hardlink, that allows to access a file given a set of locations.
- FileLink() - Constructor for class org.apache.hadoop.hbase.io.FileLink
-
- FileLink(Path, Path...) - Constructor for class org.apache.hadoop.hbase.io.FileLink
-
- FileLink(Collection<Path>) - Constructor for class org.apache.hadoop.hbase.io.FileLink
-
- FILENAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- fileSize - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Size of this file.
- fileSystemManager - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- FileSystemVersionException - Exception in org.apache.hadoop.hbase.util
-
Thrown when the file system needs to be upgraded
- FileSystemVersionException() - Constructor for exception org.apache.hadoop.hbase.util.FileSystemVersionException
-
default constructor
- FileSystemVersionException(String) - Constructor for exception org.apache.hadoop.hbase.util.FileSystemVersionException
-
- FILL_HEADER - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- fillRegion(HRegion) - Method in interface org.apache.hadoop.hbase.util.ModifyRegionUtils.RegionFillTask
-
- Filter - Interface in org.apache.hadoop.hbase.filter
-
Interface for row and column filters directly applied within the regionserver.
- filter - Variable in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- filter - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- filter - Variable in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- Filter.ReturnCode - Enum in org.apache.hadoop.hbase.filter
-
Return codes for filterValue().
- FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- FILTER_PACKAGE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
Package containing filters
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- filterAllRemaining() - Method in interface org.apache.hadoop.hbase.filter.Filter
-
If this returns true, the scan will terminate.
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that never filter all remaining can inherit this implementation that
never stops the filter early.
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- filterAllRemaining() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- FilterBase - Class in org.apache.hadoop.hbase.filter
-
Abstract base class to help you implement new Filters.
- FilterBase() - Constructor for class org.apache.hadoop.hbase.filter.FilterBase
-
- filterColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- filterColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
- filterKeyValue(KeyValue) - Method in interface org.apache.hadoop.hbase.filter.Filter
-
A way to filter based on the column family, column qualifier and/or the
column value.
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that dont filter by key value can inherit this implementation that
includes all KeyValues.
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.RowFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
-
- filterKeyValue(KeyValue) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- FilterList - Class in org.apache.hadoop.hbase.filter
-
- FilterList() - Constructor for class org.apache.hadoop.hbase.filter.FilterList
-
Default constructor, filters nothing.
- FilterList(List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
-
Constructor that takes a set of
Filter
s.
- FilterList(Filter...) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
-
Constructor that takes a var arg number of
Filter
s.
- FilterList(FilterList.Operator) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
-
Constructor that takes an operator.
- FilterList(FilterList.Operator, List<Filter>) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
-
Constructor that takes a set of
Filter
s and an operator.
- FilterList(FilterList.Operator, Filter...) - Constructor for class org.apache.hadoop.hbase.filter.FilterList
-
Constructor that takes a var arg number of
Filter
s and an operator.
- FilterList.Operator - Enum in org.apache.hadoop.hbase.filter
-
set operator
- filterOutRow - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- filterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- filterRow(List<KeyValue>) - Method in interface org.apache.hadoop.hbase.filter.Filter
-
Chance to alter the list of keyvalues to be submitted.
- filterRow() - Method in interface org.apache.hadoop.hbase.filter.Filter
-
- filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that never filter by modifying the returned List of KeyValues can
inherit this implementation that does nothing.
- filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
- filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- filterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- filterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- filterRow - Variable in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- filterRow() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- filterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- filterRow() - Method in class org.apache.hadoop.hbase.filter.RowFilter
-
- filterRow(List<KeyValue>) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- filterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- filterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- filterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- filterRowKey(byte[], int, int) - Method in interface org.apache.hadoop.hbase.filter.Filter
-
Filters a row based on the row key.
- filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that do not filter by row key can inherit this implementation that
never filters anything.
- filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RowFilter
-
- filterRowKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- filterString - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- filterString - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- filterString - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- findBigRanges(Collection<R>, int) - Static method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
Find specified number of top ranges in a big overlap group.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception
if it is not found.
- findByValue(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDeleteType
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDurability
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findCommonPrefix(ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Find length of common prefix of two parts in the buffer
- findCommonPrefix(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Find length of common prefix in two arrays.
- findCoprocessor(String) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Find a coprocessor implementation by class name
- findCoprocessorEnvironment(String) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Find a coprocessor environment by class name
- findEntry(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.wal.LRUDictionary
-
- findServerWithSameHostnamePort(Collection<ServerName>, ServerName) - Static method in class org.apache.hadoop.hbase.ServerName
-
- finish() - Method in class org.apache.hadoop.hbase.io.hfile.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
- finish(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- finish(String, String) - Method in interface org.apache.hadoop.hbase.master.SplitLogManager.TaskFinisher
-
finish the partially done task.
- finish() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- finishClose(FixedFileTrailer) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Sets remaining trailer fields, writes the trailer to disk, and optionally
closes the output stream.
- finishCurrentFile() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
-
Tell the helper to reset internal state
- finishFileInfo() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Add last bits of metadata to file info before it is written out.
- finishFileInfo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV1
-
- finishInitialization(boolean) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- finishInitialization() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Completes the initialization
- finishRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- finishRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactSelection
-
The current compaction finished, so reset the off peak compactions count
if this was an off peak compaction.
- finishRequest(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- finishSplitLogFile(String, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
Completes the work done by splitLogFile by archiving logs
- finishSplitLogFile(Path, Path, String, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- first() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- first - Variable in class org.apache.hadoop.hbase.util.Pair
-
- first() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- FIRST_META_REGIONINFO - Static variable in class org.apache.hadoop.hbase.HRegionInfo
-
HRegionInfo for first meta region
- FIRST_META_REGIONINFO - Static variable in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
HRegionInfo for first meta region
- firstKey() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- firstKey() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- firstKeyInBlock - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
First key in a block.
- FirstKeyOnlyFilter - Class in org.apache.hadoop.hbase.filter
-
A filter that will only return the first KV from each row.
- FirstKeyOnlyFilter() - Constructor for class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- firstRow() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- firstRow() - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
In HBase, the first row is represented by an empty byte array.
- firstRow() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.MemStore
-
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.Store
-
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.Store.ScanInfo
-
- FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- FIXED_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
- FixedFileTrailer - Class in org.apache.hadoop.hbase.io.hfile
-
The
HFile
has a fixed trailer which contains offsets to other
variable parts of the file.
- fixMetaHoleOnline(Configuration, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Puts the specified HRegionInfo into META.
- fixMultiAssignment(HBaseAdmin, HRegionInfo, List<ServerName>) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Fix multiple assignment by doing silent closes on each RS hosting the region
and then force ZK unassigned node to OFFLINE to trigger assignment by
master.
- fixOrphanTables() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
To fix orphan table by creating a .tableinfo file under tableDir
1.
- fixUnassigned(HBaseAdmin, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Fix unassigned by creating/transition the unassigned ZK node for this
region to OFFLINE state with a special flag to tell the master that this is
a forced operation by HBCK.
- fixupDaughters(Result, AssignmentManager, CatalogTracker) - Static method in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
Check that daughter regions are up in .META.
- floor(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- flush(ByteBuffer) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- flush(ByteBuffer, Callback<Void>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- flush(ByteBuffer) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- flush(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Flush a table or an individual region.
- flush(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Flush a table or an individual region.
- flush() - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
-
- flush() - Method in interface org.apache.hadoop.hbase.codec.Encoder
-
Let the implementation decide what to do.
- flush() - Method in class org.apache.hadoop.hbase.io.DoubleOutputStream
-
- flush() - Method in class org.apache.hadoop.hbase.io.hfile.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
- flush() - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
-
- flush() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- flush() - Method in class org.apache.hadoop.hbase.util.ByteBufferOutputStream
-
- FLUSH_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- flushBase64() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
-
Method added by PHIL.
- flushBuffer() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- flushcache() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Flush the cache.
- flushCache(long, SortedSet<KeyValue>, TimeRangeTracker, AtomicLong, MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
Write out current snapshot.
- flushCommits() - Method in class org.apache.hadoop.hbase.client.HTable
-
Executes all the buffered
Put
operations.
- flushCommits() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Executes all the buffered
Put
operations.
- flushCommits() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- flushed - Variable in class org.apache.hadoop.hbase.codec.BaseEncoder
-
- flushMetrics() - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
Notify the SchemaMetrics to flush all of the the metrics
- flushQueueSize - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
Size of the flush queue.
- flushRegion(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Flush the given region
- flushRegion(byte[], long) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Flush the given region if lastFlushTime < ifOlderThanTS
- flushRegion(HRegionInfo) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
- flushRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Flushes the given region
- flushRegion(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Flushes the given region if lastFlushTime < ifOlderThanTS
- flushRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- FlushRequester - Interface in org.apache.hadoop.hbase.regionserver
-
Request a flush.
- flushSize - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- FlushSnapshotSubprocedure - Class in org.apache.hadoop.hbase.regionserver.snapshot
-
This online snapshot implementation uses the distributed procedure framework to force a
store flush and then records the hfiles.
- FlushSnapshotSubprocedure(ProcedureMember, ForeignExceptionDispatcher, long, long, List<HRegion>, HBaseProtos.SnapshotDescription, RegionServerSnapshotManager.SnapshotSubprocedurePool) - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
- flushTime - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
time each scheduled flush takes
- forceNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Forces an existing unassigned node to the OFFLINE state for the specified
region.
- ForeignException - Exception in org.apache.hadoop.hbase.errorhandling
-
A ForeignException is an exception from another thread or process.
- ForeignException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Create a new ForeignException that can be serialized.
- ForeignException(String, String) - Constructor for exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Create a new ForeignException that can be serialized.
- ForeignExceptionDispatcher - Class in org.apache.hadoop.hbase.errorhandling
-
The dispatcher acts as the state holding entity for foreign error handling.
- ForeignExceptionDispatcher(String) - Constructor for class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- ForeignExceptionDispatcher() - Constructor for class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- ForeignExceptionListener - Interface in org.apache.hadoop.hbase.errorhandling
-
The ForeignExceptionListener is an interface for objects that can receive a ForeignException.
- ForeignExceptionSnare - Interface in org.apache.hadoop.hbase.errorhandling
-
This is an interface for a cooperative exception throwing mechanism.
- FOREVER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- FOREVER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Unlimited time-to-live.
- format - Variable in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- format - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- format - Variable in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- FORMAT_VERSION_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
The configuration key for HFile version to use for new files
- formatMetrics(Map<String, Long>) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
Formats the given map of metrics in a human-readable way.
- formatStats(BloomFilterBase) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
A human-readable string with statistics for the given Bloom filter.
- formatTestingStats() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- formatThreadInfo(ThreadInfo, String) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
Format the given ThreadInfo object as a String.
- forMethod(Class<T>, String, Object...) - Static method in class org.apache.hadoop.hbase.client.coprocessor.Batch
-
Creates a new
Batch.Call
instance that invokes a method
with the given parameters and returns the result.
- forMethod(Method, Object...) - Static method in class org.apache.hadoop.hbase.client.coprocessor.Batch
-
Creates a new
Batch.Call
instance that invokes a method
with the given parameters and returns the result.
- frags - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- freeMemory(long) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Free the requested amount of memory from the LRU map.
- fromByte(byte) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
- fromBytes(byte[]) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
- fromBytes(byte[]) - Static method in class org.apache.hadoop.hbase.executor.RegionTransitionData
-
Get an instance from bytes.
- fromRowSpec(String, RowSpec, Filter) - Static method in class org.apache.hadoop.hbase.rest.ResultGenerator
-
- fromScan(Scan) - Static method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- fs - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- fs - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- fs - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- FS_SHUTDOWN_HOOK_WAIT - Static variable in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
Key for a long configuration on how much time to wait on the fs shutdown
hook.
- fsBlockReader - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Filesystem-level block reader for this HFile format version.
- FSHDFSUtils - Class in org.apache.hadoop.hbase.util
-
Implementation for hdfs
- FSHDFSUtils() - Constructor for class org.apache.hadoop.hbase.util.FSHDFSUtils
-
- FSMapRUtils - Class in org.apache.hadoop.hbase.util
-
- FSMapRUtils() - Constructor for class org.apache.hadoop.hbase.util.FSMapRUtils
-
- fsOk - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- fsPreadLatency - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
filesystem positional read latency
- fsPreadLatencyHistogram - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
filesystem pread latency distribution
- fsReadLatency - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
filesystem read latency
- fsReadLatencyHistogram - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
filesystem sequential read latency distribution
- fsSyncLatency - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
filesystem sync latency
- FSTableDescriptors - Class in org.apache.hadoop.hbase.util
-
Implementation of
TableDescriptors
that reads descriptors from the
passed filesystem.
- FSTableDescriptors(FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- FSTableDescriptors(FileSystem, Path, boolean) - Constructor for class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- FSUtils - Class in org.apache.hadoop.hbase.util
-
Utility methods for interacting with the underlying file system.
- FSUtils() - Constructor for class org.apache.hadoop.hbase.util.FSUtils
-
- FSUtils.DirFilter - Class in org.apache.hadoop.hbase.util
-
A PathFilter
that returns directories.
- FSUtils.DirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.DirFilter
-
- FSUtils.FamilyDirFilter - Class in org.apache.hadoop.hbase.util
-
Filter for all dirs that are legal column family names.
- FSUtils.FamilyDirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilter
-
- FSUtils.HFileFilter - Class in org.apache.hadoop.hbase.util
-
Filter for HFiles that excludes reference files.
- FSUtils.HFileFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
-
- FSUtils.RegionDirFilter - Class in org.apache.hadoop.hbase.util
-
Filter for all dirs that don't start with '.'
- FSUtils.RegionDirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
-
- FSVisitor - Class in org.apache.hadoop.hbase.util
-
Utility methods for interacting with the hbase.root file system.
- FSVisitor.LogFileVisitor - Interface in org.apache.hadoop.hbase.util
-
- FSVisitor.RecoveredEditsVisitor - Interface in org.apache.hadoop.hbase.util
-
- FSVisitor.StoreFileVisitor - Interface in org.apache.hadoop.hbase.util
-
- fsWriteLatency - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
filesystem write latency
- fsWriteLatencyHistogram - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
Metrics on the distribution of filesystem write latencies (improved version of fsWriteLatency)
- fsWriteSize - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
size (in bytes) of data in HLog append calls
- fullScan(CatalogTracker, Set<String>) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Performs a full scan of .META.
, skipping regions from any
tables in the specified set of disabled tables.
- fullScan(CatalogTracker, Set<String>, boolean) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Performs a full scan of .META.
, skipping regions from any
tables in the specified set of disabled tables.
- fullScan(CatalogTracker) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Performs a full scan of .META.
.
- fullScan(CatalogTracker, MetaReader.Visitor) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Performs a full scan of .META.
.
- fullScan(CatalogTracker, MetaReader.Visitor, byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Performs a full scan of .META.
.
- fullScan(HRegionInterface, MetaReader.Visitor, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Deprecated.
Does not retry; use fullScan xxx instead.
x
- fullScanMetaAndPrint(CatalogTracker) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
- fullScanOfRoot(CatalogTracker) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Performs a full scan of a -ROOT-
table.
- fuzzyMatch(String) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
-
- fuzzyNormalize(String) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
-
- FuzzyRowFilter - Class in org.apache.hadoop.hbase.filter
-
Filters data based on fuzzy row key.
- FuzzyRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
Used internally for reflection, do NOT use it directly
- FuzzyRowFilter(List<Pair<byte[], byte[]>>) - Constructor for class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- generalBloomFilter - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- generateExceptionForChecksumFailureForTest(boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
-
Mechanism to throw an exception in case of hbase checksum
failure.
- generateSchemaMetricsPrefix(String, String) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
Method to transform a combination of a table name and a column family name
into a metric key prefix.
- generateSchemaMetricsPrefix(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- generateSchemaMetricsPrefix(String, Set<byte[]>) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
Method to transform a set of column families in byte[] format with table
name into a metric key prefix.
- generateToken(String) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- GENERICEXCEPTION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- get(ByteBuffer, AGet) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.AClusterStatus
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.AColumn
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.AColumnValue
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.ADelete
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.AFamilyDescriptor
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.AGet
-
- get(int) - Method in exception org.apache.hadoop.hbase.avro.generated.AIllegalArgument
-
- get(int) - Method in exception org.apache.hadoop.hbase.avro.generated.AIOError
-
- get(int) - Method in exception org.apache.hadoop.hbase.avro.generated.AMasterNotRunning
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.APut
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.ARegionLoad
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.AResult
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.AResultEntry
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.AScan
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.AServerAddress
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.AServerInfo
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.AServerLoad
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.ATableDescriptor
-
- get(int) - Method in exception org.apache.hadoop.hbase.avro.generated.ATableExists
-
- get(int) - Method in class org.apache.hadoop.hbase.avro.generated.ATimeRange
-
- get(ByteBuffer, AGet, Callback<AResult>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- get(ByteBuffer, AGet) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- Get - Class in org.apache.hadoop.hbase.client
-
Used to perform Get operations on a single row.
- Get() - Constructor for class org.apache.hadoop.hbase.client.Get
-
Constructor for Writable.
- Get(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(byte[], RowLock) - Constructor for class org.apache.hadoop.hbase.client.Get
-
- 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(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Create a new HFileSystem object, similar to FileSystem.get().
- get(Object) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- get() - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
- get() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Get the data from the BytesWritable.
- get() - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Returns the server instance called under or null.
- get(byte[], Get) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Perform Get operation.
- get() - Static method in class org.apache.hadoop.hbase.ipc.RequestContext
-
- get() - Static method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
Get singleton instance.
- get(Get) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- get(Get, Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
row locks (lockId) held outside the extent of the operation are deprecated.
- get(byte[], Get) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Perform Get operation.
- get(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- get(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Retrieves the value associated with the specified key.
- 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(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ExistsResource
-
- get(int) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- get(int) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.MultiRowResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RegionsResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
- get(UriInfo, int, int) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.StorageClusterStatusResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.StorageClusterVersionResource
-
- get(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.rest.VersionResource
-
Build a response for a version request.
- get(ZooKeeperWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- get(String) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
- get(byte[]) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
- get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.get_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.get_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get a single TCell for the specified table, row, and column at the
latest timestamp.
- get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Deprecated.
- get(ByteBuffer, ByteBuffer, byte[], byte[], Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- get(ByteBuffer, TGet, AsyncMethodCallback<THBaseService.AsyncClient.get_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- get(ByteBuffer, TGet, AsyncMethodCallback<THBaseService.AsyncClient.get_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- get(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- get - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
the TGet to check for
- get - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
the TGet to fetch
- get(ByteBuffer, TGet) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Method for getting data from a row.
- get(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- get(byte[]) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- get(String) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- get(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- get() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- get() - Method in class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
-
- get(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- get(String) - Method in enum org.apache.hadoop.hbase.zookeeper.ZKSplitLog.TaskState
-
- getAbortNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Get the full znode path for the node used by the coordinator or member to trigger an abort
of the global barrier acquisition or execution in subprocedures.
- getAbortZNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAbortZnode() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAcquireBarrierNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Get the full znode path for the node used by the coordinator to trigger a global barrier
acquire on each subprocedure.
- getAcquiredBarrier() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAcquiredBarrierNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAction() - Method in class org.apache.hadoop.hbase.client.Action
-
- getActions() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- getActiveLogFiles() - Static method in class org.apache.hadoop.hbase.monitoring.LogMonitoring
-
- getActiveMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Gets the current active master, if available.
- getActiveMaster() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- getActiveMasterManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getAddress(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getAdmin() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getAll() - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Get Map of all HTableDescriptors.
- getAll() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- getAllCached() - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- getAllEncoders() - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Provide access to all data block encoders, even those which are not
exposed in the enum.
- getAllExecutorStatuses() - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- 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(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.
- getAlterStatus(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Used by the client to get the number of regions that have received the
updated schema
- getAlterStatus(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Get the number of regions of the table that have been updated by the alter.
- getAmmount() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- getAmount() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- getAnswer(byte[]) - Method in class org.apache.hadoop.hbase.client.MultiPutResponse
-
Deprecated.
- getAny() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- getAny() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- getArchivedStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getArchivedStoreFileSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getArchivePath() - Method in class org.apache.hadoop.hbase.io.HFileLink
-
- getArchivePath(Configuration) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the full path to the archive directory on the configured FileSystem
- getAssignmentManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getAssignmentManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getAssignmentManager() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- getAssignmentManager() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getAssignmentManager__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.Factory
-
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.Factory
-
- getAttemptTimes() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- 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
-
- getAttribute(String) - Method in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
-
- getAttribute(String) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- getAttribute(String) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Return a table descriptor value as a string.
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Delete attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Delete attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Delete attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Delete attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Mutation attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
Mutation attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Mutation attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Mutation attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Scan attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Scan attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Scan attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Scan attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Scan attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Scan attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- 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
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getAttrs(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getAttrs(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getAttrsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getAttrsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getAttrsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getAttrsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getAttrsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getAttrsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getAttrsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getAttrsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getAttrsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getAttrsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getAuthenticationToken() - Method in interface org.apache.hadoop.hbase.security.token.AuthenticationProtocol
-
Obtains a token capable of authenticating as the current user for future
connections.
- getAuthenticationToken() - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- getAvailablePath(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Compute the average load across all region servers.
- getAverageLoad() - Method in interface org.apache.hadoop.hbase.master.MXBean
-
Get Average Load
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.MXBeanImpl
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Compute the average load across all region servers.
- getAverageLoad() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getAverageLoad() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- getAvg(ColumnInterpreter<T, S>, Scan) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- getAvg(ColumnInterpreter<T, S>, Scan) - Method in interface org.apache.hadoop.hbase.coprocessor.AggregateProtocol
-
Gives a Pair with first object as Sum and second object as row count,
computed for a given combination of column qualifier and column family in
the given row range as defined in the Scan object.
- getBackingFs() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Returns the underlying filesystem
- getBackReferenceFileName(Path) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
Get the referenced file name from the reference link directory path.
- getBackReferencesDir(Path, String) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
Get the directory to store the link back references
- 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.TsvImporterMapper
-
- getBaseZnode() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getBatch() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getBatch() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- getBatchSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
- getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- getBindAddress() - Method in class org.apache.hadoop.hbase.HServerAddress
-
Deprecated.
- getBlock(BlockCacheKey, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Fetch block from cache.
- getBlock(BlockCacheKey, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
- getBlock(BlockCacheKey, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the buffer of the block with the specified name.
- getBlock(BlockCacheKey, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
- getBlock(BlockCacheKey, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- getBlock(BlockCacheKey, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
Get the buffer of the block with the specified name.
- getBlockCache() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns the block cache.
- getBlockCacheColumnFamilySummaries(Configuration) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Performs a BlockCache summary and returns a List of BlockCacheColumnFamilySummary objects.
- getBlockCacheColumnFamilySummaries(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
- getBlockCacheColumnFamilySummaries(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getBlockCacheColumnFamilySummaries(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
- getBlockCacheColumnFamilySummaries(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- getBlockCacheColumnFamilySummaries(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
- getBlockCacheColumnFamilySummaries() - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Performs a BlockCache summary and returns a List of BlockCacheColumnFamilySummary objects.
- getBlockCacheColumnFamilySummaries() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getBlockCount() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the number of blocks currently cached in the block cache.
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
- getBlockForCaching() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Creates a new HFileBlock.
- getBlockLocalityIndex(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
return the locality index of a given host
- getBlockMetricName(BlockType.BlockCategory, boolean, SchemaMetrics.BlockMetricType) - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- getBlocks() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- getBlocksize() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockWritable
-
The type of block this data should use.
- getBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getBloomBlockSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- getBloomFilterNbHashes() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getBloomFilterVectorSize() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getBloomMetricName(boolean) - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- getBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getBoundedCachedThreadPool(int, long, TimeUnit, ThreadFactory) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Create a new CachedThreadPool with a bounded number as the maximum
thread size in the pool.
- getBuffer() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getBuffer() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getBuffer() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
- getBufferReadOnly() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the buffer this block stores internally.
- getBulkLoadTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Return the timestamp at which this bulk load file was generated.
- getByteBuffer() - Method in class org.apache.hadoop.hbase.util.ByteBufferOutputStream
-
This flips the underlying BB so be sure to use it _last_!
- getBytes() - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the raw binary encoding of this Result.
- getBytes() - Method in class org.apache.hadoop.hbase.executor.RegionTransitionData
-
Get the bytes for this instance.
- getBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
This method will get a sequence of bytes from pos -> limit,
but will restore pos after.
- getBytes() - Method in class org.apache.hadoop.hbase.util.HashedBytes
-
- getBytes(Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
- getBytes(Writable...) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Put a bunch of Writables as bytes all into the one byte array.
- getByteSize() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
- getByteSize() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getByteSize() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- getBytesPerChecksum(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.Store
-
Returns the configured bytesPerChecksum value.
- getByteStream() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- 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.
- getCacheConfig() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
Used for tests.
- getCacheKey() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getCaching() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getCaching() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Get the number of rows that will be fetched on next
- getCaching() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getCaching() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getCatalogTracker() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getCatalogTracker() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCatalogTracker() - Method in interface org.apache.hadoop.hbase.Server
-
- getCategory() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- getCause(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getCauses() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getCell() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- getCells() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- getChance() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- getChecksumFailuresCount() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Number of checksum verification failures.
- getChecksumObject() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
-
returns a object that can be used to generate/validate checksums
- getChecksumType(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.Store
-
Returns the configured checksum algorithm.
- getChildDataAndWatchForNewChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Returns the date of child znodes of the specified znode.
- getChildren(String, Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getChildren is an idempotent operation.
- getChildren(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getChildren is an idempotent operation.
- getClass(byte) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- getClassLoader(Path, ClassLoader, String, Configuration) - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
Get a CoprocessorClassLoader for a coprocessor jar path from cache.
- getClassLoadingLock(String) - Method in class org.apache.hadoop.hbase.util.ClassLoaderBase
-
Returns the lock object for class loading operations.
- getClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
- getClient() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getClient() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
If an RPC call is currently running, produces a String representation of
the connection from which it was received.
- getClient(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client.Factory
-
- getClient(TProtocol, TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client.Factory
-
- getClient(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client.Factory
-
- getClient(TProtocol, TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client.Factory
-
- getClientMethodsHash() - Method in class org.apache.hadoop.hbase.ipc.Invocation
-
- getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getClientVersion() - Method in exception org.apache.hadoop.hbase.ipc.HBaseRPC.VersionMismatch
-
- getClosestRowBefore(byte[], byte[], byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Return all the data for the row that matches row exactly,
or the one that immediately preceeds it.
- getClosestRowBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Return all the data for the row that matches row exactly,
or the one that immediately preceeds it, at or immediately before
ts.
- getClosestRowBefore(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCluster() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
- getClusterId() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getClusterId() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getClusterId() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- getClusterId() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getClusterId() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getClusterId() - Method in interface org.apache.hadoop.hbase.master.MXBean
-
Get the Cluster ID
- getClusterId() - Method in class org.apache.hadoop.hbase.master.MXBeanImpl
-
- getClusterId() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Get the id of the original cluster
- getClusterId(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the value of the unique cluster ID stored for this HBase instance.
- getClusterIds() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getClusterIds() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- getClusterKey() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the cluster key of that peer
- getClusterStatus() - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- getClusterStatus(Callback<AClusterStatus>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- getClusterStatus() - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- getClusterStatus() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getClusterStatus() - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Return cluster status.
- getClusterStatus() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getClusterStatus() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- getClusterStatusResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- getClusterVersion() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- getClusterVersionResource() - Method in class org.apache.hadoop.hbase.rest.VersionResource
-
Dispatch to StorageClusterVersionResource
- getCode() - Method in enum org.apache.hadoop.hbase.KeyValue.Type
-
- getCode() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getCode() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
-
- getColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Return the KeyValues for the specific column.
- getColumn() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- getColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- getColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getColumn() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
name of column
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
name of column whose value is to be deleted
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
name of column whose value is to be deleted
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
column name
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
column name
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
column name
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- getColumnDescriptors(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getColumnDescriptors_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getColumnDescriptors(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getColumnDescriptors_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getColumnDescriptors(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getColumnDescriptors(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
List all the column families assoicated with a table.
- getColumnDescriptors(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
list of column family descriptors
- getColumnFamiliesIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- getColumnFamiliesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- getColumnFamily() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- getColumnFamily(int) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Retrieve the column family at the given index from the table descriptor
- getColumnFamilyName() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getColumnFamilyName() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
- getColumnFamilyName() - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
- getColumnFamilyName() - Method in interface org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics.SchemaAware
-
- getColumnFamilyName() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getColumnHint() - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Used by matcher and scan/get to get a hint of the next column
to seek to after checkColumn() returns SKIP.
- getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
- getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
Used by matcher and scan/get to get a hint of the next column
to seek to after checkColumn() returns SKIP.
- getColumnLatest(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
The KeyValue for the most recent for a given column.
- getColumnName() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- getColumns() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getColumns() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getColumns(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getColumns(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getColumns() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
List of columns to return, null for all columns
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
List of columns to return, null for all columns
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
List of columns to return, null for all columns
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
List of columns to return, null for all columns
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
columns to scan.
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
columns to scan.
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
the columns you want returned
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
columns to scan.
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
columns to scan.
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getColumnsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getColumnsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getColumnsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getColumnsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getColumnsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getColumnsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getColumnsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getColumnsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getColumnsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getColumnsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getColumnsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getColumnsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getColumnValues() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getColumnValues() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- getColumnValuesIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getColumnValuesIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- getColumnValuesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getColumnValuesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- getCompactionCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompactionCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompactionProgress() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
getter for CompactionProgress object
- getCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
Returns the current size of the queue containing regions that are
processed.
- getCompactionRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCompactionRequester() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- 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.
- getCompactionState(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Get the current compaction state of the region.
- getCompactionState(long) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Find out if a given region in compaction now.
- getCompactionState(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Get the current compaction state of the region.
- getCompactPriority() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCompactPriority() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getCompactPriority(int) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getCompactSelection() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Gets the compact selection object for the request
- getCompactSelectionRatio() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactSelection
-
If the current hour falls in the off peak times and there are no
outstanding off peak compactions, the current compaction is
promoted to an off peak compaction.
- getCompactSplitThread() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- 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
-
- getComparator() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getComparator() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getComparator() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.Store.ScanInfo
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getComparator() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
- getComparator() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getComparator() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- getComparator() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- getComparatorIgnoringTimestamps() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- getComparatorIgnoringType() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- getCompleteCacheFlushSequenceId(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Get the sequence number to be associated with this cache flush.
- getCompletedSnapshotDir(HBaseProtos.SnapshotDescription, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory for a specified snapshot.
- getCompletedSnapshotDir(String, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory for a completed snapshot.
- getCompletedSnapshots() - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
- getCompletedSnapshots() - Method in class org.apache.hadoop.hbase.master.HMaster
-
List the currently available/stored snapshots.
- getCompletedSnapshots() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Gets the list of all completed snapshots.
- getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getCompletionTimestamp() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
- getCompletionTimestamp() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getCompression() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- getCompression() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getCompressionAlgorithm() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getCompressionAlgorithm() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getCompressionAlgorithmByName(String) - Static method in class org.apache.hadoop.hbase.io.hfile.Compression
-
- getCompressionCodec() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompressor() - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
-
- getConf() - Method in class org.apache.hadoop.hbase.BaseConfigurable
-
- getConf() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- getConf() - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
- getConf() - Method in class org.apache.hadoop.hbase.ipc.Invocation
-
- getConf() - Method in class org.apache.hadoop.hbase.ipc.SecureRpcEngine
-
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.TotalOrderPartitioner
-
- 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
-
- getConf() - Method in class org.apache.hadoop.hbase.master.DefaultLoadBalancer
-
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getConf() - Method in class org.apache.hadoop.hbase.tool.Canary
-
- getConf() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- getConf() - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- 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.coprocessor.CoprocessorHost.Environment
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the configuration object required to communicate with this peer
- getConfiguration() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.Server
-
Gets the configuration object for this server.
- getConfiguration() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- getConnection() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
- getConnection() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getConnection() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Get the connection that goes with the passed conf
configuration instance.
- getConnection() - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
This method will be changed from public to package protected.
- getConnection(InetSocketAddress, Class<? extends VersionedProtocol>, User, int, HBaseClient.Call) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- getConnection(SocketChannel, long) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Subclasses of HBaseServer can override this to provide their own
Connection implementations.
- getConnection(SocketChannel, long) - Method in class org.apache.hadoop.hbase.ipc.SecureServer
-
- getConnectionForEnvironment(CoprocessorEnvironment) - Static method in class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
Create an unmanaged
HConnection
based on the environment in which we are running the
coprocessor.
- getContext(Class<?>) - Method in class org.apache.hadoop.hbase.rest.provider.JAXBContextResolver
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- getCoprocessors() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Used to create a parameter to the HServerLoad constructor so that
HServerLoad can provide information about the coprocessors loaded by this
regionserver.
- getCoprocessors() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Return the list of attached co-processor represented by their name className
- getCoprocessors() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getCoprocessors() - Method in interface org.apache.hadoop.hbase.master.MXBean
-
Get the co-processors
- getCoprocessors() - Method in class org.apache.hadoop.hbase.master.MXBeanImpl
-
- getCoprocessors() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCoprocessors() - Method in interface org.apache.hadoop.hbase.regionserver.MXBean
-
Get loaded co-processors
- getCoprocessors() - Method in class org.apache.hadoop.hbase.regionserver.MXBeanImpl
-
- getCopyOfOnlineRegionsSortedBySize() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCorePoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getCorePoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getCorrupted() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getCount() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
-
- getCountersMapSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getCountersMapSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- getCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getCreationTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
- getCreationTime() - Method in class org.apache.hadoop.hbase.snapshot.HSnapshotDescription
-
- getCurrent() - Method in class org.apache.hadoop.hbase.client.UserProvider
-
- getCurrent() - Static method in class org.apache.hadoop.hbase.security.User
-
Returns the User
instance within current execution context.
- getCurrentCall() - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Needed for delayed calls.
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getCurrentFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- 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.
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionRecordReader
-
- getCurrentNrHRS() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
This method will be changed from public to package protected.
- getCurrentPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getCurrentPath() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get the current log that's replicated
- getCurrentPoolSize(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
- getCurrentSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the occupied size of the block cache, in bytes.
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the current size of this cache.
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
- getCurrentUserName() - Method in class org.apache.hadoop.hbase.client.UserProvider
-
- 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.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionRecordReader
-
- getCurrentValue() - Method in class org.apache.hadoop.hbase.util.SizeBasedThrottler
-
- getData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- getData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getData() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
- getData(String, Watcher, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getData is an idempotent operation.
- getData(String, boolean, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getData is an idemnpotent operation.
- getData(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the current data in the unassigned node for the specified region name
or fully-qualified path.
- getData(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get znode data.
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
-
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
-
- getData(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Gets the data of the node.
- getDataAndWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the current data in the unassigned node for the specified region name
or fully-qualified path.
- getDataAndWatch(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode and set a watch.
- getDataAndWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode and set a watch.
- getDataBlockEncoder() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- 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
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getDataBlockEncodingId() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getDataBlockEncodingOnDisk() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getDataBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getDataBlockIndexReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getDataIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getDataNoWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the current data in the unassigned node for the specified region name
or fully-qualified path.
- getDataNoWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode without setting a watch.
- getDataWriter() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Get a writable interface into bloom filter data (the actual Bloom bits).
- getDataWriter() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getDataWriter() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- 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.catalog.MetaEditor
-
Returns the daughter regions by reading from the corresponding columns of the .META.
- getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Returns the daughter regions by reading the corresponding columns of the catalog table
Result.
- getDeadNode(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getDeadNodes() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getDeadNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getDeadNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getDeadNodes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- getDeadNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getDeadNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getDeadNodesCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- getDeadNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getDeadNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getDeadNodesList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- getDeadRegionServers() - Method in interface org.apache.hadoop.hbase.master.MXBean
-
Get the dead region servers
- getDeadRegionServers() - Method in class org.apache.hadoop.hbase.master.MXBeanImpl
-
- getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getDeadServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getDeadServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getDeadServers() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getDeadServers__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getDeclaredClass() - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
- getDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- getDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getDeclaringClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
- 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.
- getDecoder(InputStream) - Method in interface org.apache.hadoop.hbase.codec.Codec
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEditCodec
-
- getDecompressor() - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
-
- getDefaultBlockSize(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Return the number of bytes that large input files should be optimally
be split into to minimize i/o time.
- getDefaultBufferSize(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the default buffer size to use during writes.
- getDefaultExecutor(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getDefaultReplication(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getDefaultValues() - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getDefaultValues() - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getDelegate() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
Retrieves the singleton instance of the
EnvironmentEdge
that is
being managed.
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
-
- getDeletableFiles(Iterable<FileStatus>) - Method in interface org.apache.hadoop.hbase.master.cleaner.FileCleanerDelegate
-
Determines which of the given files are safe to delete
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- getDeleteBloomFilterMetadata() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Retrieves delete family Bloom filter metadata as appropriate for each
HFile
version.
- getDeleteBloomFilterMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1
-
- getDeleteBloomFilterMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- getDeleteFamilyCnt() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getDeletes() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
list of TDeletes to delete
- getDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
the TDelete to execute if the check succeeds
- getDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
the TDelete to delete
- getDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- getDeletesIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- getDeletesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- getDeleteType() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getDelimiter(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- getDelimiterInReverse(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Find index of passed delimiter walking from end of buffer backwards.
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.master_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.snapshot_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.table_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.tablesDetailed_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.zk_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.regionserver.regionserver_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.rest.rest_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.thrift.thrift_jsp
-
- getDesc(List<Throwable>, List<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
-
- getDescription() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- getDeserializer() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Returns CacheableDeserializer instance which reconstructs original object from ByteBuffer.
- getDeserializer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getDestination() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Get the destination server for the plan for this region.
- getDir() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Get the directory we are making logs in.
- getDirectMemorySize() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
- getDisabledOrDisablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
-
Gets a list of all the tables set as disabled in zookeeper.
- getDisabledTables() - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Gets a list of all the tables set as disabled in zookeeper.
- getDisabledTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
-
Gets a list of all the tables set as disabled in zookeeper.
- getDrainingServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getDropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getDummyHeaderForVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Return the appropriate DUMMY_HEADER_WITH_CHECKSUM for the minor version
- getDurability() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Get the current durability
- getDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getEdit() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
-
Gets the edit
- getEffectiveEncodingInCache(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
- getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- getEnablingTableRegions(String) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Gives enabling table regions.
- getEncodedName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getEncodedName() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- getEncodedNameAsBytes() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getEncodedNameAsBytes() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- getEncodedNodeName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Gets the full path node name for the log file being split.
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
- getEncoder(OutputStream) - Method in interface org.apache.hadoop.hbase.codec.Codec
-
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec
-
Must be passed a
DataOutputStream
so KeyValues can be serialized using the usual
Writable mechanisms
- getEncoder() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Return new data block encoder for given algorithm type.
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEditCodec
-
- getEncodingById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- getEncodingCountsForTest() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getEncodingInCache() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
- getEncodingInCache() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- getEncodingInCache() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- getEncodingOnDisk() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getEncodingOnDisk() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getEncodingOnDisk() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
- getEncodingOnDisk() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- getEncodingOnDisk() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- getEnd() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getEndKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getEndKey() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- getEndKey() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getEndKey() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- getEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- getEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getEndKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
- getEndKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getEndKey() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getEndKey() - Method in interface org.apache.hadoop.hbase.util.KeyRange
-
- 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.
- getEndRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getEndRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- getEndRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getEndTime() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getEndTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- getEndTime() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getEntries() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getEntries() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getEntries() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getEntry(short) - Method in class org.apache.hadoop.hbase.regionserver.wal.LRUDictionary
-
- getEntryCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getEnvironment() - Method in class org.apache.hadoop.hbase.coprocessor.BaseEndpointCoprocessor
-
- getEnvironment() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
- getErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getErrorInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
- getErrorList() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- getErrorMonitor() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Get the ForeignExceptionDispatcher
- getErrorRate(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- getErrors() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getEventType() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Return the event type
- getEventType() - Method in class org.apache.hadoop.hbase.executor.RegionTransitionData
-
Gets the type of region transition event.
- getEvictedCount() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the number of evictions that have occurred.
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the number of blocks that have been evicted during the lifetime
of this cache.
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
- getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the number of eviction runs that have occurred
- getException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- getException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
-
Get the value of the captured exception.
- getException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getException() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTask
-
- getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getExceptionIfFailed() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Get the exception that caused the snapshot to fail, if the snapshot has failed.
- getExceptionMsg() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
- getExecutorService() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getExecutorService() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getExecutorService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getExecutorServiceType(EventHandler.EventType) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
Returns the executor service type (the thread pool instance) for the
passed event handler type.
- getExist() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- getExistsResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getExpiration() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- getExpirationDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- 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).
- getFailedDeleteCount() - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- getFailedGetCount() - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- getFailedIncrements() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getFailedIncrements() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getFailedPutCount() - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- getFailures() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns an unmodifiable collection of all the
HColumnDescriptor
of all the column families of the table.
- getFamiliesKeys() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns all the column family names of the current table.
- getFamily() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getFamily() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the HColumnDescriptor for a specific column family with name as
specified by the parameter column.
- getFamily() - Method in class org.apache.hadoop.hbase.KeyValue
-
Primarily for use client-side.
- getFamily() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
-
- getFamily() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getFamily() - Method in class org.apache.hadoop.hbase.regionserver.Store.ScanInfo
-
- getFamily() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getFamily() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
column name
- getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
column family to check
- getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
column family to check
- getFamilyDelimiterIndex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- getFamilyDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Given a particular region dir, return all the familydirs inside it
- getFamilyLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getFamilyLength(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
- 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.Increment
-
Method for retrieving the increment's familyMap
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the put's familyMap
- getFamilyMap(byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Map of qualifiers to values.
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Scan
-
Getting the familyMap
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getFamilyOffset(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
- getFamilySnapshotDirectories(HBaseProtos.SnapshotDescription, Path, FileStatus[]) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
-
Get the snapshot directory for each family to be added to the the snapshot
- getFieldDesc(TMutation._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
-
- getFieldValue(AlreadyExists._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- getFieldValue(BatchMutation._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- getFieldValue(ColumnDescriptor._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getFieldValue(Hbase.atomicIncrement_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- getFieldValue(Hbase.atomicIncrement_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- getFieldValue(Hbase.compact_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- getFieldValue(Hbase.compact_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- getFieldValue(Hbase.createTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- getFieldValue(Hbase.createTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- getFieldValue(Hbase.deleteAll_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- getFieldValue(Hbase.deleteAll_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- getFieldValue(Hbase.deleteAllRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- getFieldValue(Hbase.deleteAllRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- getFieldValue(Hbase.deleteAllRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- getFieldValue(Hbase.deleteAllRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- getFieldValue(Hbase.deleteAllTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- getFieldValue(Hbase.deleteAllTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- getFieldValue(Hbase.deleteTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- getFieldValue(Hbase.deleteTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- getFieldValue(Hbase.disableTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- getFieldValue(Hbase.disableTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- getFieldValue(Hbase.enableTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- getFieldValue(Hbase.enableTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- getFieldValue(Hbase.get_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- getFieldValue(Hbase.get_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- getFieldValue(Hbase.getColumnDescriptors_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- getFieldValue(Hbase.getColumnDescriptors_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- getFieldValue(Hbase.getRegionInfo_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- getFieldValue(Hbase.getRegionInfo_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- getFieldValue(Hbase.getRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- getFieldValue(Hbase.getRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- getFieldValue(Hbase.getRowOrBefore_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- getFieldValue(Hbase.getRowOrBefore_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- getFieldValue(Hbase.getRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- getFieldValue(Hbase.getRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- getFieldValue(Hbase.getRowsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- getFieldValue(Hbase.getRowsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- getFieldValue(Hbase.getRowsWithColumns_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- getFieldValue(Hbase.getRowsWithColumns_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- getFieldValue(Hbase.getRowsWithColumnsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getFieldValue(Hbase.getRowsWithColumnsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- getFieldValue(Hbase.getRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- getFieldValue(Hbase.getRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- getFieldValue(Hbase.getRowWithColumns_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- getFieldValue(Hbase.getRowWithColumns_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- getFieldValue(Hbase.getRowWithColumnsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- getFieldValue(Hbase.getRowWithColumnsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- getFieldValue(Hbase.getTableNames_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- getFieldValue(Hbase.getTableNames_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- getFieldValue(Hbase.getTableRegions_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- getFieldValue(Hbase.getTableRegions_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- getFieldValue(Hbase.getVer_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- getFieldValue(Hbase.getVer_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- getFieldValue(Hbase.getVerTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- getFieldValue(Hbase.getVerTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- getFieldValue(Hbase.increment_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- getFieldValue(Hbase.increment_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- getFieldValue(Hbase.incrementRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- getFieldValue(Hbase.incrementRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- getFieldValue(Hbase.isTableEnabled_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- getFieldValue(Hbase.isTableEnabled_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- getFieldValue(Hbase.majorCompact_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- getFieldValue(Hbase.majorCompact_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- getFieldValue(Hbase.mutateRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- getFieldValue(Hbase.mutateRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- getFieldValue(Hbase.mutateRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- getFieldValue(Hbase.mutateRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- getFieldValue(Hbase.mutateRowsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- getFieldValue(Hbase.mutateRowsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- getFieldValue(Hbase.mutateRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- getFieldValue(Hbase.mutateRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- getFieldValue(Hbase.scannerClose_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- getFieldValue(Hbase.scannerClose_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- getFieldValue(Hbase.scannerGet_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- getFieldValue(Hbase.scannerGet_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- getFieldValue(Hbase.scannerGetList_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- getFieldValue(Hbase.scannerGetList_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- getFieldValue(Hbase.scannerOpen_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- getFieldValue(Hbase.scannerOpen_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- getFieldValue(Hbase.scannerOpenTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- getFieldValue(Hbase.scannerOpenTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- getFieldValue(Hbase.scannerOpenWithPrefix_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- getFieldValue(Hbase.scannerOpenWithPrefix_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- getFieldValue(Hbase.scannerOpenWithScan_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- getFieldValue(Hbase.scannerOpenWithScan_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- getFieldValue(Hbase.scannerOpenWithStop_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- getFieldValue(Hbase.scannerOpenWithStop_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- getFieldValue(Hbase.scannerOpenWithStopTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- getFieldValue(Hbase.scannerOpenWithStopTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- getFieldValue(IllegalArgument._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- getFieldValue(IOError._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- getFieldValue(Mutation._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- getFieldValue(TCell._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- getFieldValue(TColumn._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- getFieldValue(TIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- getFieldValue(TRegionInfo._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getFieldValue(TRowResult._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getFieldValue(TScan._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getFieldValue(TColumn._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- getFieldValue(TColumnIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- getFieldValue(TColumnValue._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- getFieldValue(TDelete._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getFieldValue(TGet._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getFieldValue(THBaseService.checkAndDelete_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- getFieldValue(THBaseService.checkAndDelete_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- getFieldValue(THBaseService.checkAndPut_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- getFieldValue(THBaseService.checkAndPut_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- getFieldValue(THBaseService.closeScanner_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- getFieldValue(THBaseService.closeScanner_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- getFieldValue(THBaseService.deleteMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- getFieldValue(THBaseService.deleteMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- getFieldValue(THBaseService.deleteSingle_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- getFieldValue(THBaseService.deleteSingle_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- getFieldValue(THBaseService.exists_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- getFieldValue(THBaseService.exists_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- getFieldValue(THBaseService.get_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- getFieldValue(THBaseService.get_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- getFieldValue(THBaseService.getMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- getFieldValue(THBaseService.getMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- getFieldValue(THBaseService.getScannerResults_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- getFieldValue(THBaseService.getScannerResults_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- getFieldValue(THBaseService.getScannerRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- getFieldValue(THBaseService.getScannerRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- getFieldValue(THBaseService.increment_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- getFieldValue(THBaseService.increment_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- getFieldValue(THBaseService.mutateRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- getFieldValue(THBaseService.mutateRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- getFieldValue(THBaseService.openScanner_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- getFieldValue(THBaseService.openScanner_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- getFieldValue(THBaseService.put_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- getFieldValue(THBaseService.put_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- getFieldValue(THBaseService.putMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- getFieldValue(THBaseService.putMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- getFieldValue(TIllegalArgument._Fields) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- getFieldValue(TIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getFieldValue(TIOError._Fields) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- getFieldValue(TPut._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getFieldValue(TResult._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- getFieldValue(TRowMutations._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- getFieldValue(TScan._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getFieldValue(TTimeRange._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- getFileCacheForTesting() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
Exposed for Testing!
- getFileInfoOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- getFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getFileName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
- getFileName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- getFilenum() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- getFilePermissions(FileSystem, Configuration, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Get the file permissions specified in the configuration, if they are
enabled.
- getFileRegion() - Method in class org.apache.hadoop.hbase.io.Reference
-
- getFiles() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Gets the StoreFiles for the request
- getFileStatus(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
-
Get the FileStatus of the referenced file.
- getFilesToCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactSelection
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getFilesystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getFileSystem() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getFilter() - Method in class org.apache.hadoop.hbase.client.Get
-
- 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
-
- getFilter() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getFilter() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- getFilter() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getFilter() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFilter() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getFilter__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getFilter__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFilter__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getFilterArguments(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns the arguments of the filter from the filter string
- getFilterClassByName(String) - Static method in class org.apache.hadoop.hbase.util.Classes
-
Used to dynamically load a filter class.
- getFilterEntries() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
The number of Bloom filter entries in this store file, or an estimate
thereof, if the Bloom filter is not loaded.
- 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.
- getFilterString() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- 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.MultiPut
-
Deprecated.
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.
- getFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getFirstKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- getFirstKeyInBlock(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Return first key in block.
- getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- getFirstKeyInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- getFirstKeyInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getFirstKeyInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getFirstRowKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
TODO left from
HFile
version 1: move this to StoreFile after Ryan's
patch goes in to eliminate
KeyValue
here.
- getFirstRowKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getFlushableSize() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getFlushRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getFlushRequester() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getFormat() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getFormat() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFormat() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getFormat__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getFormat__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFormat__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getFormatVersion(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- getFrags() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFrags__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFreeSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the free size of the block cache, in bytes.
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the current size of this cache.
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
- getFromOnlineRegions(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getFromScope(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- getFromThrift(TGet) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Creates a
Get
(HBase) from a
TGet
(Thrift).
- getFs() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the handle on the local file system
- getGeneralBloomFilterMetadata() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Retrieves general Bloom filter metadata as appropriate for each
HFile
version.
- getGeneralBloomFilterMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1
-
- getGeneralBloomFilterMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
Returns a buffer with the Bloom filter metadata.
- getGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- getGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getGenericException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
-
- getGenericExceptionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- getGenericExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- getGenericExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getGenericExceptionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
-
- getGet() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
the TGet to check for
- getGet() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
the TGet to fetch
- getGets() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
a list of TGets to fetch, the Result list
will have the Results at corresponding positions
or null if there was an error
- getGetsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- getGetsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- getGlobalMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- getGroupName(String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Returns the actual name for a group principal (stripped of the
group prefix).
- getGroupNames() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the list of groups of which this user is a member.
- getHashCount() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getHashType() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- 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.avro.AvroServer.HBaseImpl
-
- getHBaseVersion(Callback<CharSequence>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- getHBaseVersion() - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getHBaseVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getHDFSBlocksDistribution() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This function will return the HDFS blocks distribution based on the data
captured when HFile is created
- getHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getHeadPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the head of the linked list (least recently used).
- getHeap() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- getHeapSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- getHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- getHFileBlock() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
-
- getHFileCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Exposed for Testing!
- getHFilecorruptionChecker() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getHFileFromBackReference(Path, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the full path of the HFile referenced by the back reference
- getHFileFromBackReference(Configuration, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the full path of the HFile referenced by the back reference
- getHfileName() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- getHFileNames(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Returns the store file names in the snapshot.
- getHFilesChecked() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getHFileVersion() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getHitCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitCachingRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitCachingRatioPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitCount() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the number of hits to the map.
- getHitRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitRatio() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the hit ratio.
- getHitRatioPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHLogDirectoryName(String) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Construct the HLog directory name
- getHLogNames(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Returns the log file names available in the snapshot.
- getHLogRepPosition(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Get the position of the specified hlog in the specified peer znode
- getHLogs() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a copy of the hlogs of the first source on this rs
- getHost() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
- getHostAddress() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- getHostAddress() - Method in class org.apache.hadoop.hbase.ipc.SecureServer.SecureConnection
-
- getHostAndPort() - Method in class org.apache.hadoop.hbase.ServerName
-
- getHostAndWeights() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
- getHostInetAddress() - Method in class org.apache.hadoop.hbase.ipc.SecureServer.SecureConnection
-
- getHostname() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getHostname() - Method in class org.apache.hadoop.hbase.HServerAddress
-
Deprecated.
- getHostname() - Method in class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
- getHostname() - Method in class org.apache.hadoop.hbase.ServerName
-
- getHostnameAndPort() - Method in class org.apache.hadoop.hbase.HServerAddress
-
Deprecated.
- getHostnamePort(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getHostnamePort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getHRegion() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Gets the HRegion for the request
- getHRegion() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getHRegionConnection(HServerAddress) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getHRegionConnection(String, int) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Establishes a connection to the region server at the specified address.
- getHRegionConnection(HServerAddress, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getHRegionConnection(String, int, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Establishes a connection to the region server at the specified address.
- getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.catalog.MetaEditor
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.ServerCallable
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.SplitRegionHandler
-
- getHRegionInfo() - Method in interface org.apache.hadoop.hbase.master.handler.TotesHRegionInfo
-
- getHRegionInfo(byte[]) - Static method in class org.apache.hadoop.hbase.util.Writables
-
- getHRegionInfo090x(byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaMigrationRemovingHTD
-
Deprecated.
Get HREgionInfoForMigration serialized from bytes.
- getHRegionInfoOrNull(byte[]) - Static method in class org.apache.hadoop.hbase.util.Writables
-
- getHRegionInfos(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Writables
-
- getHServerInfo() - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Deprecated.
- getHServerInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- 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(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getHTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getHTableDescriptors() - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Get array of all HTDs.
- getHTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Get array of HTDs for requested tables.
- getHTableDescriptors(List<String>) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Get HTD array for given tables
- getHTableDescriptors() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Get all table descriptors
- getHttpClient() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
if the scannerId is invalid
- getIa() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
if the scannerId is invalid
- 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
-
- getId(Class<?>) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- getId() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- getId() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the identifier of this peer
- getId() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- getId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- getId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getId() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
- getID() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- getId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
id of a scanner returned by scannerOpen
- getId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
id of a scanner returned by scannerOpen
- getId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
id of a scanner returned by scannerOpen
- getId() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getId() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterId
-
- getIdentifier(String, SecretManager<T>) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- getIfCached(Path) - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- getIncrement() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
The single increment to apply
- getIncrement() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
the TIncrement to increment
- getIncrements() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
The list of increments
- getIncrementsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- getIncrementsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- getInetSocketAddress() - Method in class org.apache.hadoop.hbase.HServerAddress
-
Deprecated.
- getInfoPort() - Method in class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
- getInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- getInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- getInfoPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfoOrBuilder
-
- getInformativeName() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Event implementations should override thie class to provide an
informative name about what event they are handling.
- getInformativeName() - Method in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- getInfoServer() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getInfoServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getInlineBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- getInlineBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
The type of blocks this block writer produces.
- getInlineBlockType() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- getInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getInMemory() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getInputStream() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
-
- getInputStream(InputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Get a SASL wrapped InputStream.
- getInstance() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getInstance() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getInstance(String, String) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
Returns a
SchemaMetrics
object for the given table and column
family, instantiating it if necessary.
- getInstance() - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- getInstance(FileSystem, Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- 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
-
- getInterfaceName() - Method in exception org.apache.hadoop.hbase.ipc.HBaseRPC.VersionMismatch
-
Get the interface name
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- getIoException() - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteResponse
-
- getIsActiveMaster() - Method in interface org.apache.hadoop.hbase.master.MXBean
-
Whether this master is the active master
- getIsActiveMaster() - Method in class org.apache.hadoop.hbase.master.MXBeanImpl
-
- getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getIssueDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getIterator() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Provides access to compressed value.
- getJar(Class) - Static method in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.JarFinder
-
Returns the full path to the Jar containing the class.
- GetJavaProperty - Class in org.apache.hadoop.hbase.util
-
A generic way for querying Java properties.
- GetJavaProperty() - Constructor for class org.apache.hadoop.hbase.util.GetJavaProperty
-
- getJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- getJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getJerseyVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
- getJVMVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- getJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getJvmVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.regionserver.Store.ScanInfo
-
- getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.ScannerV1
-
- getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Gets a buffer view to the current key.
- getKey() - Method in class org.apache.hadoop.hbase.KeyValue
-
Do not use unless you have to.
- getKey() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Get the key of this entry.
- getKey() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
-
Gets the key
- getKey() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- getKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
- getKeyClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- getKeyCount() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
- getKeyCount() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getKeyCount() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- getKeyDeepCopy() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Does a deep copy of the key at the current position.
- getKeyForNextColumn(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- getKeyForNextRow(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- getKeyId() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- getKeyId() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getKeyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getKeyString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.ScannerV1
-
- getKeyString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getKeyString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getKeyString() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Convenience method to get a copy of the key as a string - interpreting the
bytes as UTF8.
- getKeyString() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getKeyValue() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
- getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.ScannerV1
-
- getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getKeyValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- getKeyValueBuffer() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
- getKeyValues() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- getKind() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getLargestHStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getLastCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getLastContact() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- getLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getLastFlushTime(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Gets last flush time for the given region
- getLastFlushTime() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getLastFlushTime(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Gets last flush time for the given region
- getLastKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getLastKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getLastKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1
-
- getLastKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- getLastKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getLastRowKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
TODO left from
HFile
version 1: move this to StoreFile after
Ryan's patch goes in to eliminate
KeyValue
here.
- getLastRowKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getLastUpdateTime() - Method in interface org.apache.hadoop.hbase.master.MXBean.RegionsInTransitionInfo
-
Get last update time
- getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Get whether only the latest version of the column value should be compared.
- getLeases() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getLeases() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getLength() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- getLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the length of the split.
- getLength() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
- getLength() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Writer
-
- getLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
-
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getLimit() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- getLimit__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- getLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- getLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getLineNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
- getListener() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Return the socket (ip+port) on which the RPC server is listening to.
- getListenerAddress() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
-
- getListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Get a copy of current registered listeners
- getListHLogsForPeerForRS(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Get the list of hlogs for the specified region server and peer cluster
- getListOfReplicators() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Get the list of the replicators that have queues, they can be alive, dead
or simply from a previous run
- getListPeersForRS(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Get the list of peer clusters for the specified server names
- getLiveMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getLiveNode(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getLiveNodes() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getLiveNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getLiveNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getLiveNodes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- getLiveNodesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getLiveNodesBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getLiveNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getLiveNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getLiveNodesCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- getLiveNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getLiveNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getLiveNodesList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- getLiveNodesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getLiveNodesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getLiveNodesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- getLiveNodesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getLiveNodesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getLiveNodesOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- 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.HServerLoad
-
Originally, this method factored in the effect of requests going to the
server as well.
- getLoad(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getLoad(HServerAddress) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getLoadBalancer(Configuration) - Static method in class org.apache.hadoop.hbase.master.LoadBalancerFactory
-
Create a loadblanacer from the given conf.
- getLoadedCoprocessors() - Static method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- getLoadedCoprocessors() - Static method in class org.apache.hadoop.hbase.master.HMaster
-
The set of loaded coprocessors is stored in a static set.
- getLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getLoadSequence() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getLoadSequence() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getLocalFs(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Wrap a LocalFileSystem within a HFileSystem.
- getLocation() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getLocation() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- getLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- getLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getLocation() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
- getLocations() - Method in class org.apache.hadoop.hbase.io.FileLink
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region's location as an array.
- getLock(Integer, byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns existing row lock if found, otherwise
obtains a new row lock and returns it.
- getLock(Integer, HashedBytes, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns existing row lock if found, otherwise
obtains a new row lock and returns it.
- getLockEntry(long) - Method in class org.apache.hadoop.hbase.util.IdLock
-
Blocks until the lock corresponding to the given id is acquired.
- getLockId() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's lockId
- getLockId() - Method in class org.apache.hadoop.hbase.client.Increment
-
Deprecated.
RowLock
and associated operations are deprecated
- getLockId() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Deprecated.
RowLock
and associated operations are deprecated
- getLockId() - Method in class org.apache.hadoop.hbase.client.RowLock
-
Deprecated.
Get the lock id from this RowLock
- getLog() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getLog() - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
- getLogDir() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the directory where hlogs are stored by their RSs
- getLogRoller() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getLogsCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getLogsDir(Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Get log directory for a server in a snapshot.
- getLogSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
- getLogsSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getLong(Map<String, Long>, String) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- getLowestTimestamp(List<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.Store
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Returns the major version of this HFile format
- getMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to all versions of its qualifiers and values.
- getMapperClass(JobContext) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Get the application's mapper class.
- getMaster() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deprecated.
Master is an implementation detail for HBaseAdmin.
Deprecated in HBase 0.94
- getMaster() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Removed because it was a mistake exposing master in this
interface (master is an implementation detail). Master functions are
available from HConnection or HBaseAdmin, without having to use
directly the master.
Deprecated in HBase 0.94
- 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
-
- getMaster() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl.ImplData
-
- getMaster() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getMaster() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread
-
- getMasterActiveTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterActiveTime() - Method in interface org.apache.hadoop.hbase.master.MXBean
-
Get the hbase master active time
- getMasterActiveTime() - Method in class org.apache.hadoop.hbase.master.MXBeanImpl
-
- getMasterAddress() - Method in class org.apache.hadoop.hbase.MasterAddressTracker
-
Get the address of the current master if one is available.
- getMasterAddressManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getMasterFileSystem() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterFileSystem() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getMasterServices() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
-
- getMasterStartTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterStartTime() - Method in interface org.apache.hadoop.hbase.master.MXBean
-
Get hbase master start time
- getMasterStartTime() - Method in class org.apache.hadoop.hbase.master.MXBeanImpl
-
- getMasterTimerAndBindToMonitor(HBaseProtos.SnapshotDescription, Configuration, ForeignExceptionListener) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
-
Create a snapshot timer for the master which notifies the monitor when an error occurs
- getMax(ColumnInterpreter<T, S>, Scan) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- getMax(ColumnInterpreter<T, S>, Scan) - Method in interface org.apache.hadoop.hbase.coprocessor.AggregateProtocol
-
Gives the maximum for a given combination of column qualifier and column
family, in the given row range as defined in the Scan object.
- getMax() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
- getMax() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
-
- getMaxAllowedOperationTime() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getMaxChunkSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
- 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.
- getMaxFold(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- getMaxHeapMB() - Method in class org.apache.hadoop.hbase.HServerLoad
-
- getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getMaxHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- getMaximumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- getMaxKeys() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
- getMaxKeys(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- getMaxKeys() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getMaxKeys() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- getMaxMasterTimeout(Configuration, HBaseProtos.SnapshotDescription.Type, long) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- getMaxMemstoreTS() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getMaxMemstoreTS() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getMaxMemstoreTSInList(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Return the largest memstoreTS found across all storefiles in
the given list.
- getMaxMerge() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getMaxOverlapsToSideline() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getMaxPoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getMaxPoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getMaxQueueSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getMaxQueueSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getMaxRetries() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- getMaxSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getMaxSequenceIdInList(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Return the highest sequence ID found across all storefiles in
the given list.
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the maximum size of this cache.
- getMaxStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- getMaxTime() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
- getMaxTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getMaxValue() - Method in interface org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
returns the maximum value for this type T
- getMaxValues() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- 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
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.regionserver.Store.ScanInfo
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getMBeanInfo() - Method in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
-
- 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.
- getMean() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
-
- getMechanismName() - Method in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.AuthMethod
-
Return the SASL mechanism name
- getMedian(ColumnInterpreter<T, S>, Scan) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- getMedian(ColumnInterpreter<T, S>, Scan) - Method in interface org.apache.hadoop.hbase.coprocessor.AggregateProtocol
-
Gives a List containing sum of values and sum of weights.
- getMemberName() - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Each subprocedure is being executed on a member.
- getMemberName() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- getMemberName() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- getMemFree() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the currently available memory for this LRU in bytes.
- getMemMax() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the maximum memory allowed for this LRU in bytes.
- getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the size of the memstore after which a flush to filesystem is triggered.
- getMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMemStoreSizeInMB() - Method in class org.apache.hadoop.hbase.HServerLoad
-
- getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getMemstoreTS() - Method in class org.apache.hadoop.hbase.KeyValue
-
Here be dragons
- getMemUsed() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the currently used memory for this LRU in bytes.
- getMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
- getMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- getMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- getMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- getMessage() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- getMessage() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- getMetaBlock(String, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getMetaBlock(String, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1
-
- getMetaBlock(String, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- getMetaIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getMetaLocation() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
- getMetaLocation() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getMetaLocation__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getMetaLocationOrReadLocationFromRoot() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Method used by master on startup trying to figure state of cluster.
- getMetaRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
Open or return cached opened meta region
- getMETARows(byte[]) - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
- getMetaTable() - Method in class org.apache.hadoop.hbase.client.MetaScanner.BlockingMetaScannerVisitor
-
- getMetaWALActionListeners() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getMetaWriter() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Get a writable interface into bloom filter meta data.
- getMetaWriter() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getMetaWriter() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- getMethodName() - Method in class org.apache.hadoop.hbase.ipc.Invocation
-
- getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
- getMethods() - Method in class org.apache.hadoop.hbase.ipc.ProtocolSignature
-
- getMetricName(Class<?>, String) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- getMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getMetricsSnapshot() - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- getMetricsTimeVaryingLongArray() - Method in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- getMin(ColumnInterpreter<T, S>, Scan) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- getMin(ColumnInterpreter<T, S>, Scan) - Method in interface org.apache.hadoop.hbase.coprocessor.AggregateProtocol
-
Gives the minimum for a given combination of column qualifier and column
family, in the given row range as defined in the Scan object.
- 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
-
- getMin() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
-
- getMinColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMinimumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- getMinStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getMinValue() - Method in interface org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- getMinVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getMinVersions() - Method in class org.apache.hadoop.hbase.regionserver.Store.ScanInfo
-
- getMissCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMissCachingRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMissCount() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the number of misses to the map.
- getMissing() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getMissingLogsCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getMissingStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getMissRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getModificationTimeStamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getMostLoadedRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Get the top N most loaded regions this server is serving so we can tell the
master which regions it can reallocate if we're overloaded.
- getMultiple(ByteBuffer, List<TGet>, AsyncMethodCallback<THBaseService.AsyncClient.getMultiple_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- getMultiple(ByteBuffer, List<TGet>, AsyncMethodCallback<THBaseService.AsyncClient.getMultiple_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- getMultiple(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- getMultiple(ByteBuffer, List<TGet>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Method for getting multiple rows.
- getMultiple(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getMultipleRowResource(String) - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- getMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- getMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
list of mutation commands
- getMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
list of mutation commands
- getMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- getMutationsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- getMutationsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- getMutationsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- getMutationsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- getMutationsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- getMutationsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- getMutationsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- getMutationsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- getMVCC() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMvccReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getName() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- getName() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getName() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Get the name of the table as a byte array.
- getName() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getName() - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
-
- getName() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Returns this reader's "name".
- getName() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- getName() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
- getName() - Method in exception org.apache.hadoop.hbase.regionserver.Leases.LeaseStillHeldException
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.TableModel
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
- getName(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- getName(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getName(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getName() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- getName() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the full user name.
- getName() - Method in class org.apache.hadoop.hbase.snapshot.HSnapshotDescription
-
- getName() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getName() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
-
returns the name of this checksum type
- getName() - Method in class org.apache.hadoop.hbase.util.HasThread
-
- getName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Get the name of the table as a String
- getNameCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- getNameCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getNameCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
-
- getNamedThreadFactory(String) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Returns a
ThreadFactory
that names each
created thread uniquely, with a common prefix.
- 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
-
- getNameList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- getNameList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getNameList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
-
- getNbRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
number of results to return
- getNextBlockOnDiskSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
-
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getNextKeyHint(KeyValue) - Method in interface 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.
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that are not sure which key must be next seeked to, can inherit
this implementation that, by default, returns a null KeyValue.
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- getNextPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Poll for the next path
- getNextPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns the next pointer for the entry in teh LRU.
- getNextRowOrNextColumn(byte[], int, int) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Retrieve the MatchCode for the next row or column
- getNextRowOrNextColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
- getNextRowOrNextColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
- getNoChecksumFs() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Returns the filesystem that is specially setup for
doing reads from storage.
- getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
- getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
- getNodeName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the full path node name for the unassigned node for the specified
region.
- getNodeName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the name of the current node from the specified fully-qualified path.
- getNoVersionMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to their most recent qualifiers and values.
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- getNumberOfChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the number of children of the specified node.
- getNumberOfListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- getNumberOfOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getNumberOfRegions() - Method in class org.apache.hadoop.hbase.HServerLoad
-
- getNumberOfRequests() - Method in class org.apache.hadoop.hbase.HServerLoad
-
- getNumberOfStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getNumberOfThreads(JobContext) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
The number of threads in the thread pool that will run the map function.
- getNumChunks() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- getNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getNumericMetric(String) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
- getNumericMetrics() - Static method in class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
- getNumericPersistentMetric(String) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
- getNumericPersistentMetrics() - Static method in class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
- getNumExceptions() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getNumLevels() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- getNumLogFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- getNumLogFileSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- getNumPositivesForTesting(int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- getNumQueriesForTesting(int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- getNumRegions() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- getNumRootEntries() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- getNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
number of rows to return
- getNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
number of rows to return
- getNumVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
number of versions to retrieve
- getNumVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
number of versions to retrieve
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getObjectFromMessage(byte[]) - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
-
Initialize the model from a protobuf representation.
- getOccupiedSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- getOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getOffset() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getOffset() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- getOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getOffset() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
- getOldLogDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Get the directory where old logs go
- getOldLogDir() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the directory where hlogs are archived
- getOldSources() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a list of all the old sources of this rs
- getOnDiskSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getOnlineRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getOnlineRegions() - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
- getOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getOnlineRegions(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Gets the online regions of the specified table.
- getOnlineRegionsLocalContext() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
For tests and web ui.
- getOnlineServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getOnlineServers() - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
-
Gets the online servers.
- getOnlineServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getOperation(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getOperationStatus(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getOperationStatusCode() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
- 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
-
- getOrigin() - Method in class org.apache.hadoop.hbase.executor.RegionTransitionData
-
Gets the server the event originated from.
- getOriginalIndex() - Method in class org.apache.hadoop.hbase.client.Action
-
- getOriginPath() - Method in class org.apache.hadoop.hbase.io.HFileLink
-
- getOSVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- getOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getOsVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
- 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.
- getOutputStream() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- getOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Get a SASL wrapped OutputStream.
- getOverlapGroups(String) - 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
-
- getParameterClasses() - Method in class org.apache.hadoop.hbase.ipc.Invocation
-
- getParameters() - Method in class org.apache.hadoop.hbase.ipc.Invocation
-
- getParent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Returns the full path of the immediate parent of the specified node.
- getPartition(ImmutableBytesWritable, V2, int) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
Deprecated.
- getPartition(K, V, int) - Method in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.TotalOrderPartitioner
-
- 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
-
- getPartitionFile(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.TotalOrderPartitioner
-
Get the path to the SequenceFile storing the sorted partition keyset.
- getPath() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getPath() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- getPath() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getPath() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- getPath(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Return the 'path' component of a Path.
- getPath() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- getPauseTime(long, int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Calculate pause time.
- getPayload() - Method in class org.apache.hadoop.hbase.executor.RegionTransitionData
-
- getPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Helper method to connect to a peer
- getPeerClusterId() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getPeerClusterId() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get the id that the source is replicating to.
- getPeerClusters() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Get a map of all peer clusters
- getPeerClusterZnode() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getPeerClusterZnode() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get the id that the source is replicating to
- getPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the state of this peer
- getPeerEnabled(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Check whether the peer is enabled or not.
- 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 state of the peer
- getPeerState(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Get state of the peer.
- getPeersZNode() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Get the full path to the peers' znode
- getPeerUUID(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Returns the UUID of the provided peer id.
- getPoolCompletedTaskCount() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getPoolCompletedTaskCount() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getPoolLargestPoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getPoolLargestPoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getPoolSize(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- getPoolTaskCount() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getPoolTaskCount() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getPoolType(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- getPort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getPort() - Method in class org.apache.hadoop.hbase.HServerAddress
-
Deprecated.
- getPort() - Method in class org.apache.hadoop.hbase.ServerName
-
- getPort() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- getPosition() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Reader
-
- getPosition() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- getPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
-
Get the position that we stopped reading at
- getPreadLatenciesNanos() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- getPreadOps() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- getPreadTimeMs() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- 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
-
- getPrevBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getPreviousIntervalValue() - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
-
- getPrevPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns the previous pointer for the entry in the LRU.
- getPriority() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getPriority() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getPriority() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Get the priority level for this handler instance.
- getPriority() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getPriority() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
-
- getPriority() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
-
- getPriority() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Gets the priority for the request
- getProcedure(String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Returns the procedure.
- getProcedureNames() - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
The current progress of the record reader through its data.
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
The current progress of the record reader through its data.
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionRecordReader
-
- getProgressPct() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
getter for calculated percent complete
- getProto() - Method in class org.apache.hadoop.hbase.snapshot.HSnapshotDescription
-
- getProtocol() - Method in class org.apache.hadoop.hbase.client.coprocessor.Exec
-
- getProtocol() - Method in exception org.apache.hadoop.hbase.ipc.HBaseRPC.UnknownProtocolException
-
- getProtocol() - Method in class org.apache.hadoop.hbase.ipc.RequestContext
-
- getProtocolEngine(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
-
Returns a new instance of the configured
RpcEngine
implementation.
- getProtocolName() - Method in class org.apache.hadoop.hbase.client.coprocessor.Exec
-
- getProtocolSignature(String, long, int) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- getProtocolSignature(String, long, int) - Method in class org.apache.hadoop.hbase.coprocessor.BaseEndpointCoprocessor
-
- getProtocolSignature(VersionedProtocol, String, long, int) - Static method in class org.apache.hadoop.hbase.ipc.ProtocolSignature
-
Get a server protocol's signature
- getProtocolSignature(String, long, int) - Method in interface org.apache.hadoop.hbase.ipc.VersionedProtocol
-
Return protocol version corresponding to protocol interface.
- getProtocolSignature(String, long, int) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getProtocolSignature(String, long, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getProtocolSignature(String, long, int) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getProtocolVersion(String, long) - Method in class org.apache.hadoop.hbase.coprocessor.BaseEndpointCoprocessor
-
- getProtocolVersion(String, long) - Method in interface org.apache.hadoop.hbase.ipc.VersionedProtocol
-
Deprecated.
- getProtocolVersion(String, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getProtocolVersion(String, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getProtocolVersion(String, long) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getProtocolVersion(String, long) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- getProtocolVersion(String, long) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- getProxy(Class<T>, long, InetSocketAddress, Configuration, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcEngine
-
Construct a client-side proxy object.
- getProxy(Class<T>, long, InetSocketAddress, Configuration, int) - Method in class org.apache.hadoop.hbase.ipc.SecureRpcEngine
-
Construct a client-side proxy object that implements the named protocol,
talking to a server at the named address.
- getPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
the TPut to put if the check succeeds
- getPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
the TPut to put
- getPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- getPuts() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
a list of TPuts to commit
- getPutsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- getPutsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- getQosLevel(Writable) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- 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.KeyValue
-
Primarily for use client-side.
- getQualifier() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
-
- getQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
column qualifier to check
- getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
column qualifier to check
- getQualifierLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getQualifierLength(int, int) - Method in class org.apache.hadoop.hbase.KeyValue
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getQualifierOffset(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
- getQuarantined() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getQueueSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getQueueSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getQuorum() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Get the quorum address of this instance.
- getRawComparator() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- getRawComparator() - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
- getRawComparator() - Method in class org.apache.hadoop.hbase.KeyValue.RootComparator
-
- getRawKeyValues() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Get uncompressed buffer.
- getReachedBarrierNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getReachedBarrierNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Get the full znode path for the node used by the coordinator to trigger a global barrier
execution and release on each subprocedure.
- getReader() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- getReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- getReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getReader(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Get a reader for the WAL.
- getReader(FileSystem, FileStatus, Configuration, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- getReader(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- getReader() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
-
- getReadLatenciesNanos() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- getReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getReadOnly() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- getReadOps() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getReadTimeMs() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- getRecentFlushInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Deprecated.
Builds a TableRecordReader.
- 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
-
- 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.
- getRecoverableZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Get the connection to ZooKeeper.
- getRecoveredEdits(Path, String, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Get the snapshot recovered.edits file
- getRecoveredEditsDir(Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Get the snapshotted recovered.edits dir for the specified region.
- getReferencedHFileName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the HFile name of the referenced link
- getReferencedRegionName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the Region name of the referenced link
- getReferencedTableName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the Table name of the referenced link
- getReferredToFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getRegion(CatalogTracker, byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Gets the region info and assignment for the specified region.
- getRegion() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
- getRegion() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- getRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Protected utility method for safely obtaining an HRegion handle.
- getRegion(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getRegionArchiveDir(Configuration, Path, Path) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the archive directory for a given region under the specified table
- getRegionArchiveDir(Path, Path, Path) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the archive directory for a given region under the specified table
- getRegionCachePrefetch(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Check whether region cache prefetch is enabled or not.
- 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(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Check whether region cache prefetch is enabled or not for the table.
- getRegionDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionDir(Path, String) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Computes the Path of the HRegion
- getRegionDir(Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Computes the Path of the HRegion
- getRegionDirRecoveredEditsDir(Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- getRegionDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Given a particular table dir, return all the regiondirs inside it, excluding files such as
.tableinfo
- getRegionHFileReferences(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Get the list of hfiles for the specified snapshot region.
- getRegionId() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionId() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- getRegionId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getRegionInfo(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Get metainfo about an HRegion
- getRegionInfo() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionInfo(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getRegionInfo(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getRegionInfo_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRegionInfo(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getRegionInfo_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRegionInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRegionInfo(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the regininfo for the specified row.
- getRegionInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRegionLocation(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Find region location hosting passed row
- 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
-
- 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.client.Action
-
Deprecated.
- getRegionName() - Method in class org.apache.hadoop.hbase.client.coprocessor.ExecResult
-
- getRegionName() - Method in class org.apache.hadoop.hbase.client.ServerCallable
-
- getRegionName() - Method in class org.apache.hadoop.hbase.executor.RegionTransitionData
-
Gets the name of the region being transitioned.
- getRegionName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionName() - Method in class org.apache.hadoop.hbase.ipc.ExecRPCInvoker
-
- getRegionName() - Method in interface org.apache.hadoop.hbase.master.MXBean.RegionsInTransitionInfo
-
Name of region in transition
- getRegionName() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Get the encoded region name for the region this plan is for.
- getRegionName() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- getRegionName() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getRegionName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the region name from the full path node name of an unassigned node.
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getRegions() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- getRegions() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getRegions() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getRegions() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- getRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getRegions(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- getRegions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getRegions(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
- getRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getRegionsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getRegionsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getRegionsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getRegionsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getRegionsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
- getRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
-
- getRegionServerAccounting() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerAccounting() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getRegionServerFatalLogBuffer() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getRegionServerInfo(ServerName) - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
-
- getRegionServerInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getRegionServerName() - Method in interface org.apache.hadoop.hbase.master.MXBean.RegionsInTransitionInfo
-
Get Region Server name
- getRegionServerOfRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Returns the RegionServer to which hri is assigned.
- getRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getRegionServers() - Method in interface org.apache.hadoop.hbase.master.MXBean
-
Get the live region servers
- getRegionServers() - Method in class org.apache.hadoop.hbase.master.MXBeanImpl
-
- getRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get a list of all the addresses of all the region servers
for this peer cluster
- getRegionServerServices() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
- getRegionServerServices() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
-
- getRegionServerWithoutRetries(ServerCallable<T>) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Use HConnectionManager#withoutRetries(ServerCallable)
- getRegionServerWithRetries(ServerCallable<T>) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Use HConnectionManager#withoutRetries(ServerCallable)
- getRegionsInfo() - Method in class org.apache.hadoop.hbase.client.HTable
-
- 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
-
- getRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- getRegionsInTransition() - Method in interface org.apache.hadoop.hbase.master.MXBean
-
Get information on regions in transition
- getRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.MXBeanImpl
-
- getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getRegionsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getRegionsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
- getRegionsLoad() - Method in class org.apache.hadoop.hbase.HServerLoad
-
- getRegionSnapshotDirectory(HBaseProtos.SnapshotDescription, Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
-
Get the per-region snapshot description location.
- getRegionsOfTable(byte[]) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Gets the online regions of the specified table.
- getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getRegionsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getRegionsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
- getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getRegionsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getRegionsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
- getRegionSplitLimit() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- 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.
- getRegionsResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getRegionState() - Method in interface org.apache.hadoop.hbase.master.MXBean.RegionsInTransitionInfo
-
Current transition state
- getRegionStats(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionsToAdd() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the list of new regions added during the on-disk restore.
- getRegionsToRemove() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the list of regions removed during the on-disk restore.
- getRegionsToRestore() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the list of 'restored regions' during the on-disk restore.
- getRegisteredRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Get a list of all the other region servers in this cluster
and set a watch
- getRemoteAddress() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- getRemoteAddress() - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Returns remote address as a string when invoked inside an RPC.
- getRemoteAddress() - Method in class org.apache.hadoop.hbase.ipc.RequestContext
-
- getRemoteIp() - Static method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Returns the remote side ip address when invoked inside an RPC
Returns null incase of an error.
- getRemotePort() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- getReopenStatus(byte[]) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Used by the client to identify if all regions have the schema updates
- getReplicating() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Get the current status of the kill switch, if the cluster is replicating
or not.
- getReplication() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Get the replication status of this cluster.
- getReplicationManager() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Get the replication sources manager
- getReplicationSource(Configuration, FileSystem, ReplicationSourceManager, Stoppable, AtomicBoolean, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Factory method to create a replication source
- getRepZkWrapper() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the ZK help of this manager
- getRequestCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getRequestCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRequestForTesting(Store, Configuration, Collection<StoreFile>, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Create a simple compaction request just for testing - this lets you specify everything you
would need in the general case of testing compactions from an external perspective (e.g.
- getRequests() - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
-
- getRequests() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- getRequests() - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- getRequests() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getRequests() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- getRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- getRequestsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRequestsCount() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRequestUser() - Static method in class org.apache.hadoop.hbase.ipc.RequestContext
-
Returns the user credentials associated with the current RPC request or
null
if no credentials were provided.
- getRequestUserName() - Static method in class org.apache.hadoop.hbase.ipc.RequestContext
-
Returns the username for any user associated with the current RPC
request or null
if no user is set.
- getRescanNode(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- getResource(String) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- getResponseQueueSize() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- getResponseQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRestVersion() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- getRESTVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- getRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getRestVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
- getResult() - Method in class org.apache.hadoop.hbase.client.Action
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.atomicIncrement_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.compact_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.createTable_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAll_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRow_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRowTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteTable_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.disableTable_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.enableTable_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.get_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getColumnDescriptors_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRegionInfo_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRow_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowOrBefore_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRows_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumns_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumnsTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumns_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumnsTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableNames_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableRegions_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVer_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVerTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.increment_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.incrementRows_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.isTableEnabled_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.majorCompact_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRow_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRows_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowsTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerClose_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGet_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGetList_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpen_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithPrefix_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithScan_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStop_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStopTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndDelete_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndPut_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.closeScanner_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteMultiple_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteSingle_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.exists_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.get_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getMultiple_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerResults_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerRows_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.increment_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.mutateRow_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.openScanner_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.put_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.putMultiple_call
-
- getResults() - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- 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
- getRootBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootBlockDataSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootBlockKey(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootBlockOffset(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getRootDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRootDir(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getRootKeyZNode() - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- getRootLocation() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Gets the current location for -ROOT-
or null if location is
not currently available.
- getRootLocation() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getRootLocation__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getRootRegion() - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
- getRootRegionLocation() - Method in class org.apache.hadoop.hbase.zookeeper.RootRegionTracker
-
Gets the root region location, if available.
- getRow() - Method in class org.apache.hadoop.hbase.client.coprocessor.Exec
-
- 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.Increment
-
Method for retrieving the increment'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.RowLock
-
Deprecated.
Get the row for this RowLock
- getRow() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- getRow() - Method in class org.apache.hadoop.hbase.client.ServerCallable
-
- getRow() - Method in class org.apache.hadoop.hbase.KeyValue
-
Primarily for use client-side.
- getRow() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
-
- getRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- getRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
- getRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRow_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRow_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
row to increment
- getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Row to update
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
key of the row to be completely deleted.
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
key of the row to be completely deleted.
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Row to update
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
row key
- getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get all the data for the specified table and row at the latest
timestamp.
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
row to check
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
row to check
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- getRowBatches() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
list of row batches
- getRowBatches() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
list of row batches
- getRowBatchesIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- getRowBatchesIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- getRowBatchesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- getRowBatchesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- getRowComparator(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Get the appropriate row comparator for the specified table.
- getRowLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getRowLock() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's RowLock
- getRowLock() - Method in class org.apache.hadoop.hbase.client.Increment
-
Deprecated.
RowLock
and associated operations are deprecated
- getRowLock() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Deprecated.
RowLock
and associated operations are deprecated
- getRowMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
mutations to apply
- getRowNum(ColumnInterpreter<T, S>, Scan) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- getRowNum(ColumnInterpreter<T, S>, Scan) - Method in interface org.apache.hadoop.hbase.coprocessor.AggregateProtocol
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- 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 .META. and makes
various assumptions about the table (which are true for .META. but not
in general) to be efficient.
- getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getRowOrBefore_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getRowOrBefore_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the row just before the specified one.
- getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowResource(String, String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getRows() - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- getRows(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getRows(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getRows(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
-
- getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRows_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRows_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
row keys
- getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
row keys
- getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
row keys
- getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
row keys
- getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get all the data for the specified table and rows at the latest
timestamp.
- getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getRowsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getRowsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getRowsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getRowsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
-
- getRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteResponse
-
- getRowsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- getRowsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- getRowsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- getRowsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getRowsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getRowsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getRowsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
-
- getRowsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getRowsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getRowsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
-
- getRowsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getRowsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getRowsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
-
- getRowsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- getRowsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- getRowsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- getRowsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get all the data for the specified table and rows at the specified
timestamp.
- getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumns_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumns_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the specified columns for the specified table and rows at the latest
timestamp.
- getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumnsTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumnsTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the specified columns for the specified table and rows at the specified
timestamp.
- getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get all the data for the specified table and row at the specified
timestamp.
- getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumns_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumns_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the specified columns for the specified table and row at the latest
timestamp.
- getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumnsTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumnsTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the specified columns for the specified table and row at the specified
timestamp.
- getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRPC() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPC(boolean) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPC() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Produces a string representation of the method currently being serviced
by this Handler.
- getRPC(boolean) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Produces a string representation of the method currently being serviced
by this Handler.
- getRpcMetrics() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Returns the metrics instance for reporting RPC call statistics
- getRpcMetrics() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the metrics instance for reporting RPC call statistics
- getRpcMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Return a reference to the metrics instance used for counting RPC calls.
- getRPCPacketLength() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPCPacketLength() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Produces a string representation of the method currently being serviced
by this Handler.
- getRPCQueueTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPCQueueTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Accesses the queue time for the currently running RPC on the
monitored Handler.
- getRpcServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRpcServer() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns a reference to the region server's RPC server
- getRPCStartTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPCStartTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Accesses the start time for the currently running RPC on the
monitored Handler.
- getRpcTimeout() - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
-
- getRpcTimeout(int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
-
- getRpcVersion() - Method in class org.apache.hadoop.hbase.ipc.Invocation
-
Returns the rpc version used by the client.
- getRsCoprocessors() - Method in class org.apache.hadoop.hbase.HServerLoad
-
HBASE-4070: Improve region server metrics to report loaded coprocessors.
- gets - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
a list of TGets to fetch, the Result list
will have the Results at corresponding positions
or null if there was an error
- getSample(InputFormat<K, V>, Job) - Method in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.InputSampler.IntervalSampler
-
For each split sampled, emit when the ratio of the number of records
retained to the total record count is less than the specified
frequency.
- getSample(InputFormat<K, V>, Job) - Method in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.InputSampler.RandomSampler
-
Randomize the split order, then take the specified number of keys from
each split sampled, where each key is selected with the specified
probability and possibly replaced by a subsequently selected key when
the quota of keys from that split is satisfied.
- getSample(InputFormat<K, V>, Job) - Method in interface org.apache.hadoop.hbase.mapreduce.hadoopbackport.InputSampler.Sampler
-
For a given job, collect and return a subset of the keys from the
input data.
- getSample(InputFormat<K, V>, Job) - Method in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.InputSampler.SplitSampler
-
From each split sampled, take the first numSamples / numSplits records.
- getSaslQop() - Method in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.QualityOfProtection
-
- getScan() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getScan() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- 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.
- getScan() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Scan instance
- getScan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
the scan object to get a Scanner for
- getScan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
the scan object to get a Scanner for
- getScanForTableName(byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
This method creates a Scan object that will only scan catalog rows that
belong to the specified table.
- getScanInfo(Store, RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- getScanInfo() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getScanner(int) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
Returns the scanner associated with the specified ID.
- 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(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Create a Scanner on this file.
- getScanner(boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getScanner(boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1
-
Create a Scanner on this file.
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
Create a Scanner on this file.
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Return an iterator that scans over the HRegion, returning the indicated
columns and rows specified by the
Scan
.
- getScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getScanner(Scan, NavigableSet<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
Return a scanner for both the memstore and the HStore files.
- getScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
Deprecated.
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
Deprecated.
- 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
-
- getScanner(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Returns the scanner associated with the specified ID.
- getScanner() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.ResultScannerWrapper
-
- getScannerCaching() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getScannerCallable(byte[], int) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getScannerId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
the Id of the Scanner to close *
- getScannerId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
the Id of the Scanner to return rows from.
- getScannerInstanceResource(String) - Method in class org.apache.hadoop.hbase.rest.ScannerResource
-
- getScannerResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getScannerResults(ByteBuffer, TScan, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerResults_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- getScannerResults(ByteBuffer, TScan, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerResults_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- getScannerResults(ByteBuffer, TScan, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- getScannerResults(ByteBuffer, TScan, int) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Get results for the provided TScan object.
- getScannerResults(ByteBuffer, TScan, int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getScannerRows(int, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerRows_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- getScannerRows(int, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerRows_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- getScannerRows(int, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- getScannerRows(int, int) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Grabs multiple rows from a Scanner.
- getScannerRows(int, int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getScanners(boolean, boolean, boolean, ScanQueryMatcher) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
Get all scanners with no filtering based on TTL (that happens further down
the line).
- getScannersForStoreFiles(Collection<StoreFile>, boolean, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Return an array of scanners corresponding to the given
set of store files.
- getScannersForStoreFiles(Collection<StoreFile>, boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Return an array of scanners corresponding to the given set of store files.
- getScannersForStoreFiles(Collection<StoreFile>, boolean, boolean, boolean, ScanQueryMatcher) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Return an array of scanners corresponding to the given set of store files,
And set the ScanQueryMatcher for each store file scanner for further
optimization
- getScans() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to get the list of
Scan
objects.
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.AClusterStatus
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.AColumn
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.AColumnValue
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.ADelete
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.AFamilyDescriptor
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.AGet
-
- getSchema() - Method in exception org.apache.hadoop.hbase.avro.generated.AIllegalArgument
-
- getSchema() - Method in exception org.apache.hadoop.hbase.avro.generated.AIOError
-
- getSchema() - Method in exception org.apache.hadoop.hbase.avro.generated.AMasterNotRunning
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.APut
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.ARegionLoad
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.AResult
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.AResultEntry
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.AScan
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.AServerAddress
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.AServerInfo
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.AServerLoad
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.ATableDescriptor
-
- getSchema() - Method in exception org.apache.hadoop.hbase.avro.generated.ATableExists
-
- getSchema() - Method in class org.apache.hadoop.hbase.avro.generated.ATimeRange
-
- getSchemaMetrics() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
- getSchemaMetrics() - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
- getSchemaMetrics() - Method in interface org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics.SchemaAware
-
- getSchemaResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getScope() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getScopes() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- 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.
- getSecretManager() - Method in class org.apache.hadoop.hbase.ipc.SecureServer
-
- getSeqid() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- getSequenceID() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Get the sequence id associated with this KeyValueScanner.
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
-
MemStoreScanner returns max value as sequence id because it will
always have the latest data among all files.
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- getSequenceNumber() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- getSequenceNumber() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getSerializedLength() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Returns the length of the ByteBuffer required to serialized the object.
- getSerializedLength() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getServer(Object, Class<?>[], String, int, int, int, boolean, Configuration, int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
-
Construct a server for a protocol implementation instance listening on a
port and address.
- getServer(Class, Object, Class<?>[], String, int, int, int, boolean, Configuration, int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
-
Construct a server for a protocol implementation instance.
- getServer(Class<? extends VersionedProtocol>, Object, Class<?>[], String, int, int, int, boolean, Configuration, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcEngine
-
Construct a server for a protocol implementation instance.
- getServer(Class<? extends VersionedProtocol>, Object, Class<?>[], String, int, int, int, boolean, Configuration, int) - Method in class org.apache.hadoop.hbase.ipc.SecureRpcEngine
-
Construct a server for a protocol implementation instance listening on a
port and address, with a secret manager.
- getServerAddress() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getServerAddress() - Method in class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
- getServerInfo() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServerInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getServerManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getServerManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getServerManager() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getServerManager__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getServerName() - Method in class org.apache.hadoop.hbase.client.ServerCallable
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getServerName() - Method in interface org.apache.hadoop.hbase.master.MXBean
-
Get ServerName
- getServerName() - Method in class org.apache.hadoop.hbase.master.MXBeanImpl
-
- getServerName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getServerName() - Method in interface org.apache.hadoop.hbase.regionserver.MXBean
-
Return RegionServer's ServerName
- getServerName() - Method in class org.apache.hadoop.hbase.regionserver.MXBeanImpl
-
- getServerName() - Method in interface org.apache.hadoop.hbase.Server
-
- getServerName() - Method in class org.apache.hadoop.hbase.ServerName
-
- getServerName(String, int, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getServerName(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getServerName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getServerNameFromCatalogResult(Result) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
- 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
-
- getServers() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getServers__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getServersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServerStartcodeFromServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getServerStats(String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Gets the statistics from the given server.
- getServerUserRegions(CatalogTracker, ServerName) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
- getServerVersion() - Method in exception org.apache.hadoop.hbase.ipc.HBaseRPC.VersionMismatch
-
- getServerVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- getServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getServerVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
- getServices() - Method in class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- getSessionId() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getSessionPasswd() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getsFromThrift(List<TGet>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Converts multiple
TGet
s (Thrift) into a list of
Get
s (HBase).
- getSharedData() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
- getSharedStoreFilePercentage() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getSharedStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getShortName() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the shortened version of the user name -- the portion that maps
to an operating system user name.
- getShortName() - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- getShowAppendWarning() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getShowAppendWarning__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getSize() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Find the size of minimal buffer that could store compressed data.
- getSize() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- getSize() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Gets the total size of all StoreFiles in compaction
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.PlainTextMessageBodyProducer
-
- getSize(ProtobufMessageHandler, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.ProtobufMessageBodyProducer
-
- getSizeToCheck(int) - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getSlavesAddresses(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Returns all region servers from given peer
- getSlowAppendCount() - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- getSlowAppendTime() - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getSnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- getSnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- getSnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getSnapshot() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
- getSnapshot() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
-
- getSnapshotDescription() - Method in exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
- getSnapshotDescription() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getSnapshotHLogsDir(Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
-
Get the log directory for a specific snapshot
- getSnapshotList(Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the list of available snapshots in the specified location
- getSnapshotManagerForTesting() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Exposed for TESTING!
- getSnapshotRegionNames(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Returns the set of region names available in the snapshot.
- getSnapshotRootDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the snapshot root directory.
- getSnapshotsDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- getSnapshotStats(Configuration, HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the snapshot stats
- getSnapshotTimeRangeTracker() - Method in class org.apache.hadoop.hbase.regionserver.MemStore
-
- getSortedColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getSortedColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getSortedColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getSource() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
- getSource() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Get the source server for the plan for this region.
- getSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- getSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getSource() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
-
- getSourceName() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getSources() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a list of all the normal sources of this rs
- getSplitEditFilesSorted(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Returns sorted set of edit files made by wal-log splitter, excluding files
with '.temp' suffix.
- getSplitKey() - Method in class org.apache.hadoop.hbase.io.Reference
-
- getSplitLogDir(Path, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- getSplitLogDirTmpComponent(String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
Determines if Store should be split
- 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(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
-
- getSplits() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
- getStagingPath(String, byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.SecureBulkLoadClient
-
- getStagingPath(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
This returns the staging path for a given column family.
- getStamp() - Method in class org.apache.hadoop.hbase.executor.RegionTransitionData
-
Gets the timestamp when this event was created.
- getStamp() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- getStart() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getStartAndPrefix() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
the prefix (and thus start row) of the keys you want
- getStartCode() - Method in class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
- getStartcode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getStartCode() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getStartCode() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- 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
-
- getStartKey() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- getStartKey() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStartKey() - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- getStartKey() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- getStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- getStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getStartKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
- getStartKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getStartKey() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getStartKey() - Method in interface org.apache.hadoop.hbase.util.KeyRange
-
- 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.
- getStartRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getStartRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- getStartRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Starting row in table to scan.
- getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Starting row in table to scan.
- getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Starting row in table to scan.
- getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Starting row in table to scan.
- getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getStartRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getStarts() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
- getStartTime() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Call
-
- getStartTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStartTime() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getStartTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- getStartTime() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getState() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- getState() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getState() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getStateTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStats() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Get the statistics for this block cache.
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get counter statistics for this cache.
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
- getStatus() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Gets the status of this handler; if it is currently servicing an RPC,
this status will include the RPC information.
- getStatus() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStatus() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- getStatusTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStd(ColumnInterpreter<T, S>, Scan) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- getStd(ColumnInterpreter<T, S>, Scan) - Method in interface org.apache.hadoop.hbase.coprocessor.AggregateProtocol
-
Gives a Pair with first object a List containing Sum and sum of squares,
and the second object as row count.
- getStdDev() - Method in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
-
- getStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
row to stop scanning on.
- getStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
row to stop scanning on.
- getStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getStopRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- getStore() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Gets the Store for the request
- getStore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Return HStore instance.
- getStoreArchivePath(Configuration, String, String, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the directory to archive a store directory
- getStoreArchivePath(Configuration, HRegion, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the directory to archive a store directory
- getStoreArchivePath(Configuration, HRegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the directory to archive a store directory
- getStorefileIndexSizeInMB() - Method in class org.apache.hadoop.hbase.HServerLoad
-
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getStoreFileList(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Get a list of store files for a particular CF in a particular region
- getStoreFileList(byte[], byte[][]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Get a list of store files for a set of CFs in a particular region
- getStoreFileList(byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Get a list of store files for all CFs in a particular region
- getStoreFileList(byte[][]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Return list of storeFiles for the set of CFs.
- getStoreFileList(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getStoreFileList(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getStoreFileList(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getStoreFileOpenAndCloseThreadPool(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.HServerLoad
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getStorefiles() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getStoreFileScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
Get a scanner to scan over this StoreFile.
- getStoreFileScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
Get a scanner to scan over this StoreFile.
- getStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getStorefileSizeInMB() - Method in class org.apache.hadoop.hbase.HServerLoad
-
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getStoreFlusher(long) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- getStoreHomedir(Path, String, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.Store
-
- getStoreHomedir(Path, String, String) - Static method in class org.apache.hadoop.hbase.regionserver.Store
-
- getStoreHomedir(Path, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.Store
-
- getStoreMetricName(SchemaMetrics.StoreMetricType) - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- getStoreMetricNameMax(SchemaMetrics.StoreMetricType) - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- getStoreOpenAndCloseThreadPool(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStores() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStores() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getStores() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getStoreSnapshotDirectory(Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
-
Get the home directory for store-level snapshot files.
- getStructDesc() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- getSubList(int, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactSelection
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- getSuccessfulCoalescings() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getSuccessfulCoalescings() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- getSucessfulDeleteCount() - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- getSucessfulGetCount() - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- getSucessfulPutCount() - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- getSum(ColumnInterpreter<T, S>, Scan) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- getSum(ColumnInterpreter<T, S>, Scan) - Method in interface org.apache.hadoop.hbase.coprocessor.AggregateProtocol
-
Gives the sum for a given combination of column qualifier and column
family, in the given row range as defined in the Scan object.
- getSupportedCompressionAlgorithms() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Get names of supported compression algorithms.
- getSupportedFilters() - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Return a Set of filters supported by the Filter Language
- getSyncTime() - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- 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(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(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Get a reference to the specified table from the pool.
- getTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Get a reference to the specified table from the pool.
- getTable(byte[]) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Open a table from within the Coprocessor environment
- getTable(byte[], ExecutorService) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Open a table from within the Coprocessor environment
- getTable(byte[]) - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getTable(byte[], ExecutorService) - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getTable() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- getTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- getTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
- getTable() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getTable() - Method in class org.apache.hadoop.hbase.snapshot.HSnapshotDescription
-
- getTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- getTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Creates and returns an HTable instance from a given table name.
- getTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
to check in and delete from
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
to check in and put to
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
the table to delete from
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
the table to delete from
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
the table to check on
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
the table to get from
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
the table to get from
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
the table to get the Scanner for
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
the table to increment the value on
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
table to apply the mutations
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
the table to get the Scanner for
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
the table to put data in
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
the table to put data in
- getTableArchivePath(Path) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the path to the table archive directory based on the configured archive directory.
- getTableArchivePath(Path, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the path to the table archive directory based on the configured archive directory.
- getTableArchivePath(Configuration, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the path to the table archive directory based on the configured archive directory.
- getTableDesc() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Do not use; expensive call
use HRegionInfo.getTableNameAsString() in place of
HRegionInfo.getTableDesc().getNameAsString()
- getTableDesc() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- getTableDesc() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getTableDescriptor(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Method for getting the tableDescriptor
- 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.master.handler.TableEventHandler
-
Gets a TableDescriptor from the masterServices.
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- getTableDescriptor(FileSystem, Path, byte[]) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Get HTD from HDFS.
- getTableDescriptor(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- getTableDescriptorFromFs(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns the latest table descriptor for the given table directly from the file system
if it exists, bypassing the local cache.
- getTableDescriptorFromFs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns the latest table descriptor for the table located at the given directory
directly from the file system if it exists.
- getTableDescriptors(List<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get tableDescriptors
- getTableDescriptors() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getTableDescriptors() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getTableDir(Path, byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the Path
object representing the table directory under
path rootdir
- getTableDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getTableDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getTableFragmentation(HMaster) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and checks how many stores for each table
have more than one file in them.
- getTableFragmentation(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and checks how many stores for each table
have more than one file in them.
- getTableInfo() - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
- getTableInfo() - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
- getTableInfoPath(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- 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
-
Gets the table name from the specified region name.
- getTableName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Get current table name of the region
- 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.
- getTableName(byte[]) - Static method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
Gets the table name from the specified region name.
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
- getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics.SchemaAware
-
- getTablename() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
- getTableName() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
name of table to create
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
name of table to delete
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
table name
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
table name
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
name of the table to check
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getTableNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Get current table name as string
- getTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- getTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- getTableNames() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
List all of the names of userspace tables.
- getTableNames(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
List all of the names of userspace tables matching the given pattern
- getTableNames(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
List all of the names of userspace tables matching the given regex
- getTableNames() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getTableNames() - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Return all table names.
- getTableNames() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Return all table names.
- getTableNames(AsyncMethodCallback<Hbase.AsyncClient.getTableNames_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getTableNames(AsyncMethodCallback<Hbase.AsyncClient.getTableNames_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getTableNames() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getTableNames() - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
List all the userspace tables.
- getTableNames() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getTablePath(Path, byte[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getTablePath(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getTableRegions(CatalogTracker, byte[]) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Gets all of the regions of the specified table.
- getTableRegions(CatalogTracker, byte[], boolean) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Gets all of the regions of the specified table.
- getTableRegions(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
get the regions of a given table.
- getTableRegions(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getTableRegions_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getTableRegions(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getTableRegions_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getTableRegions(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getTableRegions(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
List the regions associated with a table.
- getTableRegions(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getTableRegionsAndLocations(CatalogTracker, String) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
- getTableRegionsAndLocations(CatalogTracker, byte[], boolean) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
- getTableResource(String) - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- getTables() - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- getTableStoreFilePathMap(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and creates a reverse lookup map for
table StoreFile names to the full Path.
- getTailKbParam(HttpServletRequest) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- getTailPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the tail of the linked list (most recently used).
- getTaskAttemptContext(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.InputSampler
-
This method is about making hbase portable, making it so it can run on
more than just hadoop 0.20.
- getTaskMonitor() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getTaskMonitor__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getTasks() - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
Produces a list containing copies of the current state of all non-expired
MonitoredTasks handled by this TaskMonitor.
- getTempDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getThread() - Method in class org.apache.hadoop.hbase.util.HasThread
-
- getThreadCount() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- getThreadCount() - Method in class org.apache.hadoop.hbase.master.BulkReOpen
-
Configuration knobs "hbase.bulk.reopen.threadpool.size" number of regions
that can be reopened concurrently.
- getThreadInfo(Thread) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
- getThreadNamePrefix() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- getThreadReadPoint() - Static method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Get this thread's read point.
- getThreadWakeFrequency() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Interval at which threads should run
- getThreshold() - Method in class org.apache.hadoop.hbase.util.SizeBasedThrottler
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
-
- getTime() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- getTimeoutOnRIT() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- 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
-
- getTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- 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
- getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getTimestamp() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getTimestampOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getTimestampOffset(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
- getTimestamps() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- getTimeToLive() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getTimeToLive() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getTimeToPurgeDeletes() - Method in class org.apache.hadoop.hbase.regionserver.Store.ScanInfo
-
- getTimeVaryingMetric(String) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
- getTimeVaryingMetrics() - Static method in class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
- getToken(String, String) - Method in class org.apache.hadoop.hbase.security.User
-
Returns the Token of the specified kind associated with this user,
or null if the Token is not present.
- getTop(int) - Method in class org.apache.hadoop.hbase.metrics.ExactCounterMetric
-
- getTopHosts() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
return the sorted list of hosts in terms of their weights
- getTopHostsWithWeights() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
return the sorted list of hosts in terms of their weights
- getTotalBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getTotalColumnLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getTotalColumnLength(int, int) - Method in class org.apache.hadoop.hbase.KeyValue
-
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getTotalIncrements() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getTotalIncrements() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.HServerLoad
-
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getTotalTableFragmentation(HMaster) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the total overall fragmentation percentage.
- getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getTotalUncompressedSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
The total uncompressed size of the root index block, intermediate-level
index blocks, and leaf-level index blocks.
- getTrace(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getTrace(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getTrace(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
- getTraceBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getTraceBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getTraceCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getTraceCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getTraceCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
- getTraceList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getTraceList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getTraceList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
- getTraceOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getTraceOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getTraceOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
- getTraceOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getTraceOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getTraceOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
- getTrailer() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getTrailer() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getTrailerSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getTtl() - Method in class org.apache.hadoop.hbase.regionserver.Store.ScanInfo
-
- getTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getTtl() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- getType() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getType() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
-
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
- getType() - Method in class org.apache.hadoop.hbase.snapshot.HSnapshotDescription
-
- getUGI() - Method in class org.apache.hadoop.hbase.security.User
-
- getUncaughtExceptionHandler() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- getUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getUncompressedSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getUniqueBlocksTotalWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
- getUniqueFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getUnknownInstanceForTest() - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
Creates an instance pretending both the table and column family are
unknown.
- getUrl() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the subversion URL for the root hbase directory.
- getUsage() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- getUsage() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
-
- getUsage() - Method in class org.apache.hadoop.hbase.util.ServerCommandLine
-
Implementing subclasses should return a usage string to print out.
- getUsedHeapMB() - Method in class org.apache.hadoop.hbase.HServerLoad
-
- getUser() - Method in class org.apache.hadoop.hbase.ipc.RequestContext
-
- getUser() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- getUser() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getUser() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
The user that compiled hbase.
- getUsername() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getUserPermissions(byte[]) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getUserPermissions(byte[]) - Method in interface org.apache.hadoop.hbase.security.access.AccessControllerProtocol
-
Queries the permissions currently stored for the given table, returning
a list of currently granted permissions, along with the user or group
each is associated with.
- getUUIDForCluster(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Get the UUID for the provided ZK watcher.
- getValue(byte[], byte[], KeyValue) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.ExecResult
-
- getValue(byte[], byte[], KeyValue) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Get the latest version of the specified column.
- getValue(byte[], byte[], KeyValue) - Method in interface org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- getValue() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- getValue() - Method in class org.apache.hadoop.hbase.filter.WritableByteArrayComparable
-
- 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
- getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.ScannerV1
-
- getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Gets a buffer view to the current value.
- getValue() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns value in a new byte array.
- getValue() - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
-
- getValue() - Method in class org.apache.hadoop.hbase.metrics.MetricsString
-
- getValue() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Get the value of this entry.
- getValue() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- getValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
-
- getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- getValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
-
- getValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
amount to increment by
- getValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- getValue() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- getValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- getValue() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TDeleteType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TDurability
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
the expected value, if not provided the
check is for the non-existence of the
column in question
- getValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
the expected value, if not provided the
check is for the non-existence of the
column in question
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- getValueLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getValues(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getValues(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getValues(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
- getValuesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getValuesBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getValuesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getValuesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getValuesCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
- getValueShallowCopy() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Does a shallow copy of the value at the current position.
- getValuesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getValuesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getValuesList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
- getValuesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getValuesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getValuesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
- getValuesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getValuesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getValuesOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
- getValueString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.ScannerV1
-
- getValueString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getValueString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getValueString() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Convenience method to get a copy of the value as a string - interpreting
the bytes as UTF8.
- getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getVer_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getVer_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the specified number of versions for the specified table,
row, and column.
- getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Deprecated.
- getVer(ByteBuffer, ByteBuffer, byte[], byte[], int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getVersion() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getVersion() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getVersion() - Method in class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
- getVersion() - Method in class org.apache.hadoop.hbase.HServerLoad
-
- getVersion() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getVersion() - Method in class org.apache.hadoop.hbase.ipc.Invocation
-
- getVersion() - Method in class org.apache.hadoop.hbase.ipc.ProtocolSignature
-
- getVersion() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
- getVersion() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
- getVersion() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- getVersion() - Method in class org.apache.hadoop.hbase.snapshot.HSnapshotDescription
-
- getVersion() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies current version of file system
- getVersion() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the hbase version.
- getVersion(ZooKeeperWatcher, HRegionInfo) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Get the version of the specified znode
- getVersionedBytes() - Method in class org.apache.hadoop.hbase.ServerName
-
- getVersionResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- getVersionResource() - Method in class org.apache.hadoop.hbase.rest.VersionResource
-
Dispatch /version/rest to self.
- getVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteResponse
-
- getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getVerTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getVerTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the specified number of versions for the specified table,
row, and column.
- getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Deprecated.
- getVerTs(ByteBuffer, ByteBuffer, byte[], byte[], long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getWAL() - Method in interface org.apache.hadoop.hbase.coprocessor.WALCoprocessorEnvironment
-
- getWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getWAL(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getWAL(HRegionInfo) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getWAL() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getWALActionListeners() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getWALActionsListener() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSourceService
-
Returns a WALObserver for the service.
- getWALActionsListener() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- getWalEdit(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getWatcher() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getWebAppsPath(String) - Method in class org.apache.hadoop.hbase.util.InfoServer
-
Get the pathname to the webapps files.
- getWebAppsPath() - Method in class org.apache.hadoop.hbase.util.InfoServer
-
Get the pathname to the path
files.
- getWebuiPort() - Method in class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
- getWeight(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
return the weight for a specific host, that will be the total bytes of all
blocks on the host
- getWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
- getWorkingSnapshotDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the general working directory for snapshots - where they are built, where they are
temporarily copied on export, etc.
- getWorkingSnapshotDir(HBaseProtos.SnapshotDescription, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory to build a snapshot, before it is finalized
- getWorkingSnapshotDir(String, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory to build a snapshot, before it is finalized
- getWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Set bytes into the passed Writable by calling its
Writable.readFields(java.io.DataInput)
.
- getWritable(byte[], int, int, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Set bytes into the passed Writable by calling its
Writable.readFields(java.io.DataInput)
.
- getWritableSize() - Method in class org.apache.hadoop.hbase.client.Result
-
- getWritableSize() - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
- getWritableSize(Object, Class, Configuration) - Static method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
- getWritableSize() - Method in interface org.apache.hadoop.hbase.io.WritableWithSize
-
Provide a size hint to the caller.
- getWriteArraySize(Result[]) - Static method in class org.apache.hadoop.hbase.client.Result
-
- getWriteBuffer() - Method in class org.apache.hadoop.hbase.client.HTable
-
Returns the write buffer.
- 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
-
- getWriteLatenciesNanos() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- getWriteOps() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- getWriter() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- getWriterFactory(Configuration, CacheConfig) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns the factory to be used to create
HFile
writers
- getWriterFactoryNoCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns the factory to be used to create
HFile
writers.
- getWriterFSDataOutputStream() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
-
- getWriterName(byte[]) - Method in enum org.apache.hadoop.hbase.zookeeper.ZKSplitLog.TaskState
-
- getWriteSize() - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- getWriteTime() - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- getWriteTime() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
- getWriteTimeMs() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- getWriteToWAL() - Method in class org.apache.hadoop.hbase.client.Increment
-
Method for retrieving whether WAL will be written to or not
- getWriteToWAL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getZkController() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- getZKPermissionWatcher() - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- getZKQuorumServersString(Properties) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Return the ZK Quorum servers string given zk properties returned by
makeZKProps
- getZKQuorumServersString(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Return the ZK Quorum servers string given the specified configuration.
- getZKTable() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- getZkw() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the ZK connection to this peer
- getZNodeName(String) - Static method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Extracts the znode name of a peer cluster from a ZK path
- getZooKeeper() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getZooKeeper() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getZooKeeper() - Method in interface org.apache.hadoop.hbase.Server
-
Gets the ZooKeeper instance for this server.
- getZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getZooKeeperClusterKey(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the key to the ZK ensemble for this configuration without
adding a name at the end
- getZooKeeperClusterKey(Configuration, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the key to the ZK ensemble for this configuration and append
a name at the end
- getZookeeperQuorum() - Method in interface org.apache.hadoop.hbase.master.MXBean
-
Get the Zookeeper Quorum Info
- getZookeeperQuorum() - Method in class org.apache.hadoop.hbase.master.MXBeanImpl
-
- getZookeeperQuorum() - Method in interface org.apache.hadoop.hbase.regionserver.MXBean
-
Get Zookeeper Quorum
- getZookeeperQuorum() - Method in class org.apache.hadoop.hbase.regionserver.MXBeanImpl
-
- getZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getZooKeeperWatcher() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Removed because it was a mistake exposing zookeeper in this
interface (ZooKeeper is an implementation detail).
Deprecated in HBase 0.94
- getZooKeeperWatcher() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Get the ZK wrapper object - needed by master_jsp.java
- getZooKeeperWatcher() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getZookeeperWatcher() - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Get this cluster's zk connection
- globalStartTime - Variable in class org.apache.hadoop.hbase.client.ServerCallable
-
- grant(UserPermission) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- grant(byte[], TablePermission) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Deprecated.
- grant(UserPermission) - Method in interface org.apache.hadoop.hbase.security.access.AccessControllerProtocol
-
Grants the given user or group the privilege to perform the given actions
- grant(byte[], TablePermission) - Method in interface org.apache.hadoop.hbase.security.access.AccessControllerProtocol
-
- 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.
- GROUP_PREFIX - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Prefix character to denote group names
- 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.
- GzipFilter - Class in org.apache.hadoop.hbase.rest.filter
-
- GzipFilter() - Constructor for class org.apache.hadoop.hbase.rest.filter.GzipFilter
-
- GZIPRequestStream - Class in org.apache.hadoop.hbase.rest.filter
-
- GZIPRequestStream(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- GZIPRequestWrapper - Class in org.apache.hadoop.hbase.rest.filter
-
- GZIPRequestWrapper(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
-
- GZIPResponseStream - Class in org.apache.hadoop.hbase.rest.filter
-
- GZIPResponseStream(HttpServletResponse) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- GZIPResponseWrapper - Class in org.apache.hadoop.hbase.rest.filter
-
- GZIPResponseWrapper(HttpServletResponse) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- H - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'H'
- HalfStoreFileReader - Class in org.apache.hadoop.hbase.io
-
A facade for a
HFile.Reader
that serves up
either the top or bottom half of a HFile where 'bottom' is the first half
of the file containing the keys that sort lowest and 'top' is the second half
of the file with keys that sort greater than those of the bottom half.
- HalfStoreFileReader(FileSystem, Path, CacheConfig, Reference, DataBlockEncoding) - Constructor for class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
Creates a half file reader for a normal hfile.
- HalfStoreFileReader(FileSystem, Path, HFileLink, CacheConfig, Reference, DataBlockEncoding) - Constructor for class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
Creates a half file reader for a hfile referred to by an hfilelink.
- handle(Callback[]) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslDigestCallbackHandler
- handle(Callback[]) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslGssCallbackHandler
- handleCoprocessorThrowable(CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
This is used by coprocessor hooks which are declared to throw IOException
(or its subtypes).
- handleCreateHdfsRegions(Path, String) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
Create the on-disk structure for the table, and returns the regions info.
- handleCreateHdfsRegions(Path, String) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
Create the on-disk regions, using the tableRootDir provided by the CreateTableHandler.
- handleDegenerateRegion(HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling a region that has the same start and end key.
- handleDegenerateRegion(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling a region that has the same start and end key.
- handleDuplicateStartKeys(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling two regions that have the same start key.
- handleDuplicateStartKeys(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling two regions that have the same start key.
- handleHoleInRegionChain(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling a region hole between two keys.
- handleHoleInRegionChain(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling a region hole between two keys.
- handleOverlapGroup(Collection<HBaseFsck.HbckInfo>) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling an group of regions that overlap.
- handleOverlapGroup(Collection<HBaseFsck.HbckInfo>) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling an group of regions that overlap.
- handleOverlapInRegionChain(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling two reigons that overlap in some arbitrary way.
- handleOverlapInRegionChain(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling two reigons that overlap in some arbitrary way.
- handleRegionEndKeyNotEmpty(byte[]) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling case where a Table has a last region that does not
have an empty end key.
- handleRegionEndKeyNotEmpty(byte[]) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling case where a Table has a last region that does not
have an empty end key.
- handleRegionStartKeyNotEmpty(HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling case where a Table has a first region that does not
have an empty start key.
- handleRegionStartKeyNotEmpty(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling case where a Table has a first region that does not
have an empty start key.
- handleReportForDutyResponse(MapWritable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- handleSplitReport(ServerName, HRegionInfo, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Update inmemory structures.
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.ModifyTableHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
The restore table is executed in place.
- 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.
- has(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Check to see if the Constraint is currently set.
- hasAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- hasAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- hasAverageLoad() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- hasBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- hasBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- hasBatch() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- hasBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- hasClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- hasClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- hasClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
- hasClusterId(UUID) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- hasColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- hasColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- hasColumn() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
- hasColumns() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- hasCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- hasCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- hasCompression() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- hasCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the table has an attached co-processor represented by the name className
- hasCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- hasCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- hasCreationTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
- hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- hasData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- hasData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- hasData() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
- hasDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- hasDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- hasDeclaringClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
- hasEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- hasEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- hasEndKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
- hasEndRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- hasEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- hasEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- hasEndRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- hasEndRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- hasEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- hasEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- hasEndTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- hasErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- hasErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- hasErrorInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
- hasException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- hasException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
-
- hasException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- hasException() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTask
-
- 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
- hasFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- hasFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- hasFileName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
- hasFilter() - Method in class org.apache.hadoop.hbase.client.Scan
-
- hasFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- hasFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- hasFilter() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- hasFilterRow() - Method in interface org.apache.hadoop.hbase.filter.Filter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Fitlers that never filter by modifying the returned List of KeyValues can
inherit this implementation that does nothing.
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- hasGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- hasGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- hasGenericException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
-
- hash - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
The hash value for this entries key
- hash - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Hash Function
- 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
-
- hashCode() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionKey
-
- hashCode() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- 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.HServerAddress
-
Deprecated.
- hashCode() - Method in class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
- hashCode() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- hashCode() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- hashCode() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.ConnectionId
-
- hashCode() - Method in class org.apache.hadoop.hbase.KeyValue
-
- hashCode() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
- hashCode() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- hashCode() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns the hash code of the entry by xor'ing the hash values
of the key and value of this entry.
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Intentionally unimplemented.
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.User
-
- hashCode() - Method in class org.apache.hadoop.hbase.ServerName
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
-
- hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- hashCode() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- hashCode() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
If you'd like this to perform more respectably, use the hashcode generator option.
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- 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.HashedBytes
-
- hashCode() - Method in class org.apache.hadoop.hbase.util.Pair
-
- hashCode() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
- hashCount - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Number of hash functions
- hasHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- hasHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- hasHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- HashedBytes - Class in org.apache.hadoop.hbase.util
-
This class encapsulates a byte array and overrides hashCode and equals so
that it's identity is based on the data rather than the array instance.
- HashedBytes(byte[]) - Constructor for class org.apache.hadoop.hbase.util.HashedBytes
-
- hasHigherPriority(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns which operator has higher precedence
- hashType - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Hash type
- hashType - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
Hash function type to use, as defined in
Hash
- hasId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- hasId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- hasId() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
- hasId() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterId
-
- hasInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- hasInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- hasInfoPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfoOrBuilder
-
- hasInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- hasInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- hasInMemory() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- hasJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- hasJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- hasJerseyVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
- hasJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- hasJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- hasJvmVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
- hasKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- hasKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- hasKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
- hasKeyInScope(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- hasLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
- hasLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- hasLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- hasLineNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
- hasLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- hasLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- hasLocation() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
- hasMaster() - Method in class org.apache.hadoop.hbase.MasterAddressTracker
-
Check if there is a master available.
- hasMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- hasMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- hasMaxHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- hasMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- hasMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- hasMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- hasMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- hasMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
- hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- hasMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
- hasMVCCInfo() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- hasMVCCInfo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- hasMVCCInfo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- hasNext() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
-
- hasNext() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- hasNullColumnInQuery() - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- hasOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- hasOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- hasOsVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
- hasReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- hasReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- hasReadOnly() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
- hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasReadRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- hasReferences() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- hasRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- hasRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- hasRegions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- hasRegionsToAdd() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- hasRegionsToRemove() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- hasRegionsToRestore() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- hasRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- hasRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
- hasRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- hasRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- hasRestVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
- hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- hasRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- hasRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- hasRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
- hasServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- hasServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- hasServerVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
- hasSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- hasSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- hasSource() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
-
- hasStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- hasStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- hasStartCode() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
- hasStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- hasStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- hasStartKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
- hasStartRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- hasStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- hasStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- hasStartRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- hasStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- hasStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- hasStartTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
- hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- hasStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasStorefiles() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- hasStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasStores() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- hasTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
- hasTable() - Method in class org.apache.hadoop.hbase.snapshot.HSnapshotDescription
-
- HasThread - Class in org.apache.hadoop.hbase.util
-
Abstract class which contains a Thread and delegates the common Thread
methods to that instance.
- HasThread() - Constructor for class org.apache.hadoop.hbase.util.HasThread
-
- HasThread(String) - Constructor for class org.apache.hadoop.hbase.util.HasThread
-
- hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- hasTimestamp() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
- hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- hasTooManyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- hasTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- hasTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- hasTtl() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
- hasUserTimestamp() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- hasValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
-
- hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- hasValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
-
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
- hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- hasWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
- haveRootRegion - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- HBase - Interface in org.apache.hadoop.hbase.avro.generated
-
- Hbase - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase
-
- Hbase.AsyncClient - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- Hbase.AsyncClient.atomicIncrement_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.atomicIncrement_call(ByteBuffer, ByteBuffer, ByteBuffer, long, AsyncMethodCallback<Hbase.AsyncClient.atomicIncrement_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.atomicIncrement_call
-
- Hbase.AsyncClient.compact_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.compact_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.compact_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.compact_call
-
- Hbase.AsyncClient.createTable_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.createTable_call(ByteBuffer, List<ColumnDescriptor>, AsyncMethodCallback<Hbase.AsyncClient.createTable_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.createTable_call
-
- Hbase.AsyncClient.deleteAll_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.deleteAll_call(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAll_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAll_call
-
- Hbase.AsyncClient.deleteAllRow_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.deleteAllRow_call(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAllRow_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRow_call
-
- Hbase.AsyncClient.deleteAllRowTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.deleteAllRowTs_call(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAllRowTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRowTs_call
-
- Hbase.AsyncClient.deleteAllTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.deleteAllTs_call(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAllTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllTs_call
-
- Hbase.AsyncClient.deleteTable_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.deleteTable_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.deleteTable_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteTable_call
-
- Hbase.AsyncClient.disableTable_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.disableTable_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.disableTable_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.disableTable_call
-
- Hbase.AsyncClient.enableTable_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.enableTable_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.enableTable_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.enableTable_call
-
- Hbase.AsyncClient.Factory - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.Factory
-
- Hbase.AsyncClient.get_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.get_call(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.get_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.get_call
-
- Hbase.AsyncClient.getColumnDescriptors_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getColumnDescriptors_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getColumnDescriptors_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getColumnDescriptors_call
-
- Hbase.AsyncClient.getRegionInfo_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRegionInfo_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getRegionInfo_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRegionInfo_call
-
- Hbase.AsyncClient.getRow_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRow_call(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRow_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRow_call
-
- Hbase.AsyncClient.getRowOrBefore_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowOrBefore_call(ByteBuffer, ByteBuffer, ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getRowOrBefore_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowOrBefore_call
-
- Hbase.AsyncClient.getRows_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRows_call(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRows_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRows_call
-
- Hbase.AsyncClient.getRowsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowsTs_call(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsTs_call
-
- Hbase.AsyncClient.getRowsWithColumns_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowsWithColumns_call(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumns_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumns_call
-
- Hbase.AsyncClient.getRowsWithColumnsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowsWithColumnsTs_call(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumnsTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumnsTs_call
-
- Hbase.AsyncClient.getRowTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowTs_call(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowTs_call
-
- Hbase.AsyncClient.getRowWithColumns_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowWithColumns_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumns_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumns_call
-
- Hbase.AsyncClient.getRowWithColumnsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowWithColumnsTs_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumnsTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumnsTs_call
-
- Hbase.AsyncClient.getTableNames_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getTableNames_call(AsyncMethodCallback<Hbase.AsyncClient.getTableNames_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableNames_call
-
- Hbase.AsyncClient.getTableRegions_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getTableRegions_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getTableRegions_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableRegions_call
-
- Hbase.AsyncClient.getVer_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getVer_call(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getVer_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVer_call
-
- Hbase.AsyncClient.getVerTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getVerTs_call(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getVerTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVerTs_call
-
- Hbase.AsyncClient.increment_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.increment_call(TIncrement, AsyncMethodCallback<Hbase.AsyncClient.increment_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.increment_call
-
- Hbase.AsyncClient.incrementRows_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.incrementRows_call(List<TIncrement>, AsyncMethodCallback<Hbase.AsyncClient.incrementRows_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.incrementRows_call
-
- Hbase.AsyncClient.isTableEnabled_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.isTableEnabled_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.isTableEnabled_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.isTableEnabled_call
-
- Hbase.AsyncClient.majorCompact_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.majorCompact_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.majorCompact_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.majorCompact_call
-
- Hbase.AsyncClient.mutateRow_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.mutateRow_call(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.mutateRow_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRow_call
-
- Hbase.AsyncClient.mutateRows_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.mutateRows_call(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.mutateRows_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRows_call
-
- Hbase.AsyncClient.mutateRowsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.mutateRowsTs_call(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.mutateRowsTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowsTs_call
-
- Hbase.AsyncClient.mutateRowTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.mutateRowTs_call(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.mutateRowTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowTs_call
-
- Hbase.AsyncClient.scannerClose_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerClose_call(int, AsyncMethodCallback<Hbase.AsyncClient.scannerClose_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerClose_call
-
- Hbase.AsyncClient.scannerGet_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerGet_call(int, AsyncMethodCallback<Hbase.AsyncClient.scannerGet_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGet_call
-
- Hbase.AsyncClient.scannerGetList_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerGetList_call(int, int, AsyncMethodCallback<Hbase.AsyncClient.scannerGetList_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGetList_call
-
- Hbase.AsyncClient.scannerOpen_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerOpen_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpen_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpen_call
-
- Hbase.AsyncClient.scannerOpenTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerOpenTs_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenTs_call
-
- Hbase.AsyncClient.scannerOpenWithPrefix_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerOpenWithPrefix_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithPrefix_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithPrefix_call
-
- Hbase.AsyncClient.scannerOpenWithScan_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerOpenWithScan_call(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithScan_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithScan_call
-
- Hbase.AsyncClient.scannerOpenWithStop_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerOpenWithStop_call(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStop_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStop_call
-
- Hbase.AsyncClient.scannerOpenWithStopTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerOpenWithStopTs_call(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStopTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStopTs_call
-
- Hbase.AsyncIface - Interface in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.atomicIncrement_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.atomicIncrement_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- Hbase.atomicIncrement_args(ByteBuffer, ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- Hbase.atomicIncrement_args(Hbase.atomicIncrement_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
Performs a deep copy on other.
- Hbase.atomicIncrement_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.atomicIncrement_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.atomicIncrement_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- Hbase.atomicIncrement_result(long, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- Hbase.atomicIncrement_result(Hbase.atomicIncrement_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
Performs a deep copy on other.
- Hbase.atomicIncrement_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- HBase.Callback - Interface in org.apache.hadoop.hbase.avro.generated
-
- Hbase.Client - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Client(TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- Hbase.Client(TProtocol, TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- Hbase.Client.Factory - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Client.Factory() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client.Factory
-
- Hbase.compact_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.compact_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- Hbase.compact_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- Hbase.compact_args(Hbase.compact_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
Performs a deep copy on other.
- Hbase.compact_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.compact_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.compact_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- Hbase.compact_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- Hbase.compact_result(Hbase.compact_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
Performs a deep copy on other.
- Hbase.compact_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.createTable_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.createTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- Hbase.createTable_args(ByteBuffer, List<ColumnDescriptor>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- Hbase.createTable_args(Hbase.createTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
Performs a deep copy on other.
- Hbase.createTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.createTable_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.createTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- Hbase.createTable_result(IOError, IllegalArgument, AlreadyExists) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- Hbase.createTable_result(Hbase.createTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
Performs a deep copy on other.
- Hbase.createTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAll_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAll_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- Hbase.deleteAll_args(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- Hbase.deleteAll_args(Hbase.deleteAll_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Performs a deep copy on other.
- Hbase.deleteAll_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAll_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAll_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- Hbase.deleteAll_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- Hbase.deleteAll_result(Hbase.deleteAll_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
Performs a deep copy on other.
- Hbase.deleteAll_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAllRow_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAllRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- Hbase.deleteAllRow_args(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- Hbase.deleteAllRow_args(Hbase.deleteAllRow_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Performs a deep copy on other.
- Hbase.deleteAllRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAllRow_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAllRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- Hbase.deleteAllRow_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- Hbase.deleteAllRow_result(Hbase.deleteAllRow_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
Performs a deep copy on other.
- Hbase.deleteAllRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAllRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAllRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- Hbase.deleteAllRowTs_args(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- Hbase.deleteAllRowTs_args(Hbase.deleteAllRowTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Performs a deep copy on other.
- Hbase.deleteAllRowTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAllRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAllRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- Hbase.deleteAllRowTs_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- Hbase.deleteAllRowTs_result(Hbase.deleteAllRowTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
Performs a deep copy on other.
- Hbase.deleteAllRowTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAllTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAllTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- Hbase.deleteAllTs_args(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- Hbase.deleteAllTs_args(Hbase.deleteAllTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Performs a deep copy on other.
- Hbase.deleteAllTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAllTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAllTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- Hbase.deleteAllTs_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- Hbase.deleteAllTs_result(Hbase.deleteAllTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
Performs a deep copy on other.
- Hbase.deleteAllTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteTable_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- Hbase.deleteTable_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- Hbase.deleteTable_args(Hbase.deleteTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
Performs a deep copy on other.
- Hbase.deleteTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteTable_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- Hbase.deleteTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- Hbase.deleteTable_result(Hbase.deleteTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
Performs a deep copy on other.
- Hbase.deleteTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.disableTable_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.disableTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- Hbase.disableTable_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- Hbase.disableTable_args(Hbase.disableTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
Performs a deep copy on other.
- Hbase.disableTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.disableTable_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.disableTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- Hbase.disableTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- Hbase.disableTable_result(Hbase.disableTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
Performs a deep copy on other.
- Hbase.disableTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.enableTable_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.enableTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- Hbase.enableTable_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- Hbase.enableTable_args(Hbase.enableTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
Performs a deep copy on other.
- Hbase.enableTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.enableTable_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.enableTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- Hbase.enableTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- Hbase.enableTable_result(Hbase.enableTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
Performs a deep copy on other.
- Hbase.enableTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.get_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.get_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- Hbase.get_args(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- Hbase.get_args(Hbase.get_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Performs a deep copy on other.
- Hbase.get_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.get_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.get_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- Hbase.get_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- Hbase.get_result(Hbase.get_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
Performs a deep copy on other.
- Hbase.get_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getColumnDescriptors_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getColumnDescriptors_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- Hbase.getColumnDescriptors_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- Hbase.getColumnDescriptors_args(Hbase.getColumnDescriptors_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
Performs a deep copy on other.
- Hbase.getColumnDescriptors_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getColumnDescriptors_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getColumnDescriptors_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- Hbase.getColumnDescriptors_result(Map<ByteBuffer, ColumnDescriptor>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- Hbase.getColumnDescriptors_result(Hbase.getColumnDescriptors_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
Performs a deep copy on other.
- Hbase.getColumnDescriptors_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRegionInfo_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRegionInfo_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- Hbase.getRegionInfo_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- Hbase.getRegionInfo_args(Hbase.getRegionInfo_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
Performs a deep copy on other.
- Hbase.getRegionInfo_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRegionInfo_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRegionInfo_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- Hbase.getRegionInfo_result(TRegionInfo, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- Hbase.getRegionInfo_result(Hbase.getRegionInfo_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
Performs a deep copy on other.
- Hbase.getRegionInfo_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRow_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- Hbase.getRow_args(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- Hbase.getRow_args(Hbase.getRow_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
Performs a deep copy on other.
- Hbase.getRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRow_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- Hbase.getRow_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- Hbase.getRow_result(Hbase.getRow_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
Performs a deep copy on other.
- Hbase.getRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowOrBefore_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowOrBefore_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- Hbase.getRowOrBefore_args(ByteBuffer, ByteBuffer, ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- Hbase.getRowOrBefore_args(Hbase.getRowOrBefore_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
Performs a deep copy on other.
- Hbase.getRowOrBefore_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowOrBefore_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowOrBefore_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- Hbase.getRowOrBefore_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- Hbase.getRowOrBefore_result(Hbase.getRowOrBefore_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
Performs a deep copy on other.
- Hbase.getRowOrBefore_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRows_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRows_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- Hbase.getRows_args(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- Hbase.getRows_args(Hbase.getRows_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
Performs a deep copy on other.
- Hbase.getRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRows_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRows_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- Hbase.getRows_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- Hbase.getRows_result(Hbase.getRows_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
Performs a deep copy on other.
- Hbase.getRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- Hbase.getRowsTs_args(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- Hbase.getRowsTs_args(Hbase.getRowsTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Performs a deep copy on other.
- Hbase.getRowsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- Hbase.getRowsTs_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- Hbase.getRowsTs_result(Hbase.getRowsTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
Performs a deep copy on other.
- Hbase.getRowsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowsWithColumns_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowsWithColumns_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- Hbase.getRowsWithColumns_args(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- Hbase.getRowsWithColumns_args(Hbase.getRowsWithColumns_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Performs a deep copy on other.
- Hbase.getRowsWithColumns_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowsWithColumns_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowsWithColumns_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- Hbase.getRowsWithColumns_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- Hbase.getRowsWithColumns_result(Hbase.getRowsWithColumns_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
Performs a deep copy on other.
- Hbase.getRowsWithColumns_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowsWithColumnsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowsWithColumnsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- Hbase.getRowsWithColumnsTs_args(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- Hbase.getRowsWithColumnsTs_args(Hbase.getRowsWithColumnsTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Performs a deep copy on other.
- Hbase.getRowsWithColumnsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowsWithColumnsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowsWithColumnsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- Hbase.getRowsWithColumnsTs_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- Hbase.getRowsWithColumnsTs_result(Hbase.getRowsWithColumnsTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
Performs a deep copy on other.
- Hbase.getRowsWithColumnsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- Hbase.getRowTs_args(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- Hbase.getRowTs_args(Hbase.getRowTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Performs a deep copy on other.
- Hbase.getRowTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- Hbase.getRowTs_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- Hbase.getRowTs_result(Hbase.getRowTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
Performs a deep copy on other.
- Hbase.getRowTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowWithColumns_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowWithColumns_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- Hbase.getRowWithColumns_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- Hbase.getRowWithColumns_args(Hbase.getRowWithColumns_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Performs a deep copy on other.
- Hbase.getRowWithColumns_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowWithColumns_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowWithColumns_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- Hbase.getRowWithColumns_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- Hbase.getRowWithColumns_result(Hbase.getRowWithColumns_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
Performs a deep copy on other.
- Hbase.getRowWithColumns_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowWithColumnsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowWithColumnsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- Hbase.getRowWithColumnsTs_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- Hbase.getRowWithColumnsTs_args(Hbase.getRowWithColumnsTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Performs a deep copy on other.
- Hbase.getRowWithColumnsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowWithColumnsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowWithColumnsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- Hbase.getRowWithColumnsTs_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- Hbase.getRowWithColumnsTs_result(Hbase.getRowWithColumnsTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
Performs a deep copy on other.
- Hbase.getRowWithColumnsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getTableNames_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getTableNames_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- Hbase.getTableNames_args(Hbase.getTableNames_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
Performs a deep copy on other.
- Hbase.getTableNames_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getTableNames_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getTableNames_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- Hbase.getTableNames_result(List<ByteBuffer>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- Hbase.getTableNames_result(Hbase.getTableNames_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
Performs a deep copy on other.
- Hbase.getTableNames_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getTableRegions_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getTableRegions_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- Hbase.getTableRegions_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- Hbase.getTableRegions_args(Hbase.getTableRegions_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
Performs a deep copy on other.
- Hbase.getTableRegions_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getTableRegions_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getTableRegions_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- Hbase.getTableRegions_result(List<TRegionInfo>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- Hbase.getTableRegions_result(Hbase.getTableRegions_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
Performs a deep copy on other.
- Hbase.getTableRegions_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getVer_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getVer_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- Hbase.getVer_args(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- Hbase.getVer_args(Hbase.getVer_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Performs a deep copy on other.
- Hbase.getVer_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getVer_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getVer_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- Hbase.getVer_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- Hbase.getVer_result(Hbase.getVer_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
Performs a deep copy on other.
- Hbase.getVer_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getVerTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getVerTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- Hbase.getVerTs_args(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- Hbase.getVerTs_args(Hbase.getVerTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Performs a deep copy on other.
- Hbase.getVerTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getVerTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getVerTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- Hbase.getVerTs_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- Hbase.getVerTs_result(Hbase.getVerTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
Performs a deep copy on other.
- Hbase.getVerTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.Iface - Interface in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.increment_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.increment_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- Hbase.increment_args(TIncrement) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- Hbase.increment_args(Hbase.increment_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
Performs a deep copy on other.
- Hbase.increment_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.increment_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.increment_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- Hbase.increment_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- Hbase.increment_result(Hbase.increment_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
Performs a deep copy on other.
- Hbase.increment_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.incrementRows_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.incrementRows_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- Hbase.incrementRows_args(List<TIncrement>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- Hbase.incrementRows_args(Hbase.incrementRows_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
Performs a deep copy on other.
- Hbase.incrementRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.incrementRows_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.incrementRows_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- Hbase.incrementRows_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- Hbase.incrementRows_result(Hbase.incrementRows_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
Performs a deep copy on other.
- Hbase.incrementRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.isTableEnabled_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.isTableEnabled_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- Hbase.isTableEnabled_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- Hbase.isTableEnabled_args(Hbase.isTableEnabled_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
Performs a deep copy on other.
- Hbase.isTableEnabled_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.isTableEnabled_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.isTableEnabled_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- Hbase.isTableEnabled_result(boolean, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- Hbase.isTableEnabled_result(Hbase.isTableEnabled_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
Performs a deep copy on other.
- Hbase.isTableEnabled_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.majorCompact_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.majorCompact_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- Hbase.majorCompact_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- Hbase.majorCompact_args(Hbase.majorCompact_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
Performs a deep copy on other.
- Hbase.majorCompact_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.majorCompact_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.majorCompact_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- Hbase.majorCompact_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- Hbase.majorCompact_result(Hbase.majorCompact_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
Performs a deep copy on other.
- Hbase.majorCompact_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRow_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- Hbase.mutateRow_args(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- Hbase.mutateRow_args(Hbase.mutateRow_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Performs a deep copy on other.
- Hbase.mutateRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRow_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- Hbase.mutateRow_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- Hbase.mutateRow_result(Hbase.mutateRow_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
Performs a deep copy on other.
- Hbase.mutateRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRows_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRows_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- Hbase.mutateRows_args(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- Hbase.mutateRows_args(Hbase.mutateRows_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
Performs a deep copy on other.
- Hbase.mutateRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRows_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRows_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- Hbase.mutateRows_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- Hbase.mutateRows_result(Hbase.mutateRows_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
Performs a deep copy on other.
- Hbase.mutateRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRowsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRowsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- Hbase.mutateRowsTs_args(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- Hbase.mutateRowsTs_args(Hbase.mutateRowsTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Performs a deep copy on other.
- Hbase.mutateRowsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRowsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRowsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- Hbase.mutateRowsTs_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- Hbase.mutateRowsTs_result(Hbase.mutateRowsTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
Performs a deep copy on other.
- Hbase.mutateRowsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- Hbase.mutateRowTs_args(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- Hbase.mutateRowTs_args(Hbase.mutateRowTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Performs a deep copy on other.
- Hbase.mutateRowTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- Hbase.mutateRowTs_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- Hbase.mutateRowTs_result(Hbase.mutateRowTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
Performs a deep copy on other.
- Hbase.mutateRowTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.Processor<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor(I) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor
-
- Hbase.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor
-
- Hbase.scannerClose_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerClose_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- Hbase.scannerClose_args(int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- Hbase.scannerClose_args(Hbase.scannerClose_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
Performs a deep copy on other.
- Hbase.scannerClose_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerClose_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerClose_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- Hbase.scannerClose_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- Hbase.scannerClose_result(Hbase.scannerClose_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
Performs a deep copy on other.
- Hbase.scannerClose_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerGet_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerGet_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- Hbase.scannerGet_args(int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- Hbase.scannerGet_args(Hbase.scannerGet_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
Performs a deep copy on other.
- Hbase.scannerGet_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerGet_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerGet_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- Hbase.scannerGet_result(List<TRowResult>, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- Hbase.scannerGet_result(Hbase.scannerGet_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
Performs a deep copy on other.
- Hbase.scannerGet_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerGetList_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerGetList_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- Hbase.scannerGetList_args(int, int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- Hbase.scannerGetList_args(Hbase.scannerGetList_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
Performs a deep copy on other.
- Hbase.scannerGetList_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerGetList_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerGetList_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- Hbase.scannerGetList_result(List<TRowResult>, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- Hbase.scannerGetList_result(Hbase.scannerGetList_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
Performs a deep copy on other.
- Hbase.scannerGetList_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpen_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpen_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- Hbase.scannerOpen_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- Hbase.scannerOpen_args(Hbase.scannerOpen_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Performs a deep copy on other.
- Hbase.scannerOpen_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpen_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpen_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- Hbase.scannerOpen_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- Hbase.scannerOpen_result(Hbase.scannerOpen_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
Performs a deep copy on other.
- Hbase.scannerOpen_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- Hbase.scannerOpenTs_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- Hbase.scannerOpenTs_args(Hbase.scannerOpenTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Performs a deep copy on other.
- Hbase.scannerOpenTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- Hbase.scannerOpenTs_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- Hbase.scannerOpenTs_result(Hbase.scannerOpenTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
Performs a deep copy on other.
- Hbase.scannerOpenTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithPrefix_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithPrefix_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- Hbase.scannerOpenWithPrefix_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- Hbase.scannerOpenWithPrefix_args(Hbase.scannerOpenWithPrefix_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Performs a deep copy on other.
- Hbase.scannerOpenWithPrefix_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithPrefix_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithPrefix_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- Hbase.scannerOpenWithPrefix_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- Hbase.scannerOpenWithPrefix_result(Hbase.scannerOpenWithPrefix_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
Performs a deep copy on other.
- Hbase.scannerOpenWithPrefix_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithScan_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithScan_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- Hbase.scannerOpenWithScan_args(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- Hbase.scannerOpenWithScan_args(Hbase.scannerOpenWithScan_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Performs a deep copy on other.
- Hbase.scannerOpenWithScan_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithScan_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithScan_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- Hbase.scannerOpenWithScan_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- Hbase.scannerOpenWithScan_result(Hbase.scannerOpenWithScan_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
Performs a deep copy on other.
- Hbase.scannerOpenWithScan_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithStop_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithStop_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- Hbase.scannerOpenWithStop_args(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- Hbase.scannerOpenWithStop_args(Hbase.scannerOpenWithStop_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Performs a deep copy on other.
- Hbase.scannerOpenWithStop_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithStop_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithStop_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- Hbase.scannerOpenWithStop_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- Hbase.scannerOpenWithStop_result(Hbase.scannerOpenWithStop_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
Performs a deep copy on other.
- Hbase.scannerOpenWithStop_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithStopTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithStopTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- Hbase.scannerOpenWithStopTs_args(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- Hbase.scannerOpenWithStopTs_args(Hbase.scannerOpenWithStopTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Performs a deep copy on other.
- Hbase.scannerOpenWithStopTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithStopTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithStopTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- Hbase.scannerOpenWithStopTs_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- Hbase.scannerOpenWithStopTs_result(Hbase.scannerOpenWithStopTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
Performs a deep copy on other.
- Hbase.scannerOpenWithStopTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- 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_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_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_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_RPC_MAXATTEMPTS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for maximum attempts, used to limit the number of times the
client will try to obtain the proxy for a given region server.
- 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_CLUSTER_MANAGER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config for pluggable hbase cluster manager
- HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD - 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
-
HRegion server lease period in milliseconds.
- 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_SECURITY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
-
- 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_SNAPSHOT_ENABLED - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Enable or disable snapshot support
- 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 - Class in org.apache.hadoop.hbase.ipc
-
A client for an IPC service.
- HBaseClient(Class<? extends Writable>, Configuration, SocketFactory) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClient
-
Construct an IPC client whose values are of the given Writable
class.
- HBaseClient(Class<? extends Writable>, Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClient
-
Construct an IPC client with the default SocketFactory
- HBaseClient.Call - Class in org.apache.hadoop.hbase.ipc
-
A call waiting for a value.
- HBaseClient.Call(Writable) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClient.Call
-
- HBaseClient.CallTimeoutException - Exception in org.apache.hadoop.hbase.ipc
-
Client-side call timeout
- HBaseClient.CallTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.HBaseClient.CallTimeoutException
-
- HBaseClient.Connection - Class in org.apache.hadoop.hbase.ipc
-
Thread that reads responses and notifies callers.
- HBaseClient.Connection.PingInputStream - Class in org.apache.hadoop.hbase.ipc
-
This class sends a ping to the remote side when timeout on
reading.
- HBaseClient.Connection.PingInputStream(InputStream) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClient.Connection.PingInputStream
-
- HBaseClient.ConnectionId - Class in org.apache.hadoop.hbase.ipc
-
This class holds the address and the user ticket.
- HBaseClient.FailedServerException - Exception in org.apache.hadoop.hbase.ipc
-
- HBaseClient.FailedServerException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.HBaseClient.FailedServerException
-
- HBaseClient.ParallelCall - Class in org.apache.hadoop.hbase.ipc
-
Call implementation used for parallel calls.
- HBaseClient.ParallelCall(Writable, HBaseClient.ParallelResults, int) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClient.ParallelCall
-
- HBaseClient.ParallelResults - Class in org.apache.hadoop.hbase.ipc
-
Result collector for parallel calls.
- HBaseClient.ParallelResults(int) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseClient.ParallelResults
-
- 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.
- HBaseConfTool - Class in org.apache.hadoop.hbase.util
-
Tool that prints out a configuration.
- HBaseConfTool() - Constructor for class org.apache.hadoop.hbase.util.HBaseConfTool
-
- HBaseFileSystem - Class in org.apache.hadoop.hbase
-
An abstraction of the underlying filesystem.
- HBaseFileSystem() - Constructor for class org.apache.hadoop.hbase.HBaseFileSystem
-
- 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
- HBaseFsck.ErrorReporter - Interface in org.apache.hadoop.hbase.util
-
- HBaseFsck.ErrorReporter.ERROR_CODE - Enum in org.apache.hadoop.hbase.util
-
- HBaseFsck.HbckInfo - Class in org.apache.hadoop.hbase.util
-
Maintain information about a particular region.
- HBaseFsck.RegionRepairException - Exception in org.apache.hadoop.hbase.util
-
Exception thrown when a integrity repair operation fails in an
unresolvable way.
- HBaseFsck.RegionRepairException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.util.HBaseFsck.RegionRepairException
-
- HBaseFsck.TableInfo - Class in org.apache.hadoop.hbase.util
-
Maintain information about a particular table.
- HBaseFsckRepair - Class in org.apache.hadoop.hbase.util
-
This class contains helper methods that repair parts of hbase's filesystem
contents.
- HBaseFsckRepair() - Constructor for class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
- HbaseHandlerMetricsProxy - Class in org.apache.hadoop.hbase.thrift
-
Converts a Hbase.Iface using InvocationHandler so that it reports process
time of each call to ThriftMetrics.
- HBaseInfo - Class in org.apache.hadoop.hbase.metrics
-
Exports HBase system information as an MBean for JMX observation.
- HBaseInfo() - Constructor for class org.apache.hadoop.hbase.metrics.HBaseInfo
-
- HBaseInfo.HBaseInfoMBean - Class in org.apache.hadoop.hbase.metrics
-
- HBaseInfo.HBaseInfoMBean(MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.metrics.HBaseInfo.HBaseInfoMBean
-
- 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
- HbaseMapWritable<K,V> - Class in org.apache.hadoop.hbase.io
-
A Writable Map.
- HbaseMapWritable() - Constructor for class org.apache.hadoop.hbase.io.HbaseMapWritable
-
The default contructor where a TreeMap is used
- HbaseMapWritable(SortedMap<byte[], V>) - Constructor for class org.apache.hadoop.hbase.io.HbaseMapWritable
-
Contructor where another SortedMap can be used
- HbaseObjectWritable - Class in org.apache.hadoop.hbase.io
-
This is a customized version of the polymorphic hadoop
ObjectWritable
.
- HbaseObjectWritable() - Constructor for class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
default constructor for writable
- HbaseObjectWritable(Object) - Constructor for class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
- HbaseObjectWritable(Class<?>, Object) - Constructor for class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
- HBasePolicyProvider - Class in org.apache.hadoop.hbase.security
-
Implementation of secure Hadoop policy provider for mapping
protocol interfaces to hbase-policy.xml entries.
- HBasePolicyProvider() - Constructor for class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- HBaseProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.RegionServerInfo - Class in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.RegionServerInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.RegionServerInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.SnapshotDescription - Class in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.SnapshotDescription.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.SnapshotDescription.Type - Enum in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.SnapshotDescriptionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseRPC - Class in org.apache.hadoop.hbase.ipc
-
A simple RPC mechanism.
- HBaseRPC.UnknownProtocolException - Exception in org.apache.hadoop.hbase.ipc
-
An error requesting an RPC protocol that the server is not serving.
- HBaseRPC.UnknownProtocolException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.HBaseRPC.UnknownProtocolException
-
- HBaseRPC.UnknownProtocolException(Class<?>) - Constructor for exception org.apache.hadoop.hbase.ipc.HBaseRPC.UnknownProtocolException
-
- HBaseRPC.UnknownProtocolException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.ipc.HBaseRPC.UnknownProtocolException
-
- HBaseRPC.VersionMismatch - Exception in org.apache.hadoop.hbase.ipc
-
A version mismatch for the RPC protocol.
- HBaseRPC.VersionMismatch(String, long, long) - Constructor for exception org.apache.hadoop.hbase.ipc.HBaseRPC.VersionMismatch
-
Create a version mismatch exception
- HBaseRPCErrorHandler - Interface in org.apache.hadoop.hbase.ipc
-
An interface for calling out of RPC for error conditions.
- HBaseRpcMetrics - Class in org.apache.hadoop.hbase.ipc
-
This class is for maintaining the various RPC statistics
and publishing them through the metrics interfaces.
- HBaseRpcMetrics(String, String) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- HBaseRPCStatistics - Class in org.apache.hadoop.hbase.ipc
-
Exports HBase RPC statistics recorded in
HBaseRpcMetrics
as an MBean
for JMX monitoring.
- HBaseRPCStatistics(MetricsRegistry, String, String) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseRPCStatistics
-
- HBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
-
A utility class that encapsulates SASL logic for RPC client.
- HBaseSaslRpcClient(HBaseSaslRpcServer.AuthMethod, Token<? extends TokenIdentifier>, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Create a HBaseSaslRpcClient for an authentication method
- HBaseSaslRpcServer - Class in org.apache.hadoop.hbase.security
-
A utility class for dealing with SASL on RPC server
- HBaseSaslRpcServer() - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- HBaseSaslRpcServer.AuthMethod - Enum in org.apache.hadoop.hbase.security
-
Authentication method
- HBaseSaslRpcServer.QualityOfProtection - Enum in org.apache.hadoop.hbase.security
-
- HBaseSaslRpcServer.SaslDigestCallbackHandler - Class in org.apache.hadoop.hbase.security
-
CallbackHandler for SASL DIGEST-MD5 mechanism
- HBaseSaslRpcServer.SaslDigestCallbackHandler(SecretManager<TokenIdentifier>, SecureServer.SecureConnection) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslDigestCallbackHandler
-
- HBaseSaslRpcServer.SaslGssCallbackHandler - Class in org.apache.hadoop.hbase.security
-
CallbackHandler for SASL GSSAPI Kerberos mechanism
- HBaseSaslRpcServer.SaslGssCallbackHandler() - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslGssCallbackHandler
-
- HBaseSaslRpcServer.SaslStatus - Enum in org.apache.hadoop.hbase.security
-
- HBaseServer - Class in org.apache.hadoop.hbase.ipc
-
An abstract IPC service.
- HBaseServer(String, int, Class<? extends Writable>, int, int, Configuration, String, int) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseServer
-
- HBaseServer.Call - Class in org.apache.hadoop.hbase.ipc
-
A call queued for handling.
- HBaseServer.Call(int, Writable, HBaseServer.Connection, HBaseServer.Responder, long) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- HBaseServer.Connection - Class in org.apache.hadoop.hbase.ipc
-
Reads calls from a connection and queues them for handling.
- HBaseServer.Connection(SocketChannel, long) - Constructor for class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- HBaseServer.Responder - Class in org.apache.hadoop.hbase.ipc
-
- 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
- hbaseVersion - Variable in class org.apache.hadoop.hbase.avro.generated.AClusterStatus
-
- 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_CODE_SERVERNAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBCK_SIDELINEDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used by HBCK to sideline backup data
- hcdToAFD(HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- 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
-
Default constructor.
- 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
-
Cluster connection.
- HConnectionManager - Class in org.apache.hadoop.hbase.client
-
A non-instantiable class that manages creation of
HConnection
s.
- HConnectionManager() - Constructor for class org.apache.hadoop.hbase.client.HConnectionManager
-
- HConnectionManager.HConnectable<T> - Class in org.apache.hadoop.hbase.client
-
This class makes it convenient for one to execute a command in the context
of a
HConnection
instance based on the given
Configuration
.
- HConnectionManager.HConnectable(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HConnectionManager.HConnectable
-
- HConnectionManager.HConnectionKey - Class in org.apache.hadoop.hbase.client
-
- HConnectionManager.HConnectionKey(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionKey
-
- HConstants - Class in org.apache.hadoop.hbase
-
HConstants holds a bunch of HBase-related constants
- HConstants.Modify - Enum in org.apache.hadoop.hbase
-
modifyTable op for replacing the table descriptor
- HConstants.OperationStatusCode - Enum in org.apache.hadoop.hbase
-
Status codes used for return values of bulk operations.
- HDFSBlocksDistribution - Class in org.apache.hadoop.hbase
-
Data structure to describe the distribution of HDFS blocks amount hosts.
- HDFSBlocksDistribution() - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Constructor
- HDFSBlocksDistribution.HostAndWeight - Class in org.apache.hadoop.hbase
-
Stores the hostname and weight for that hostname.
- HDFSBlocksDistribution.HostAndWeight(String, long) - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
Constructor
- HDFSBlocksDistribution.HostAndWeight.WeightComparator - Class in org.apache.hadoop.hbase
-
comparator used to sort hosts based on weight
- HDFSBlocksDistribution.HostAndWeight.WeightComparator() - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
-
- hdfsBlocksLocalityIndex - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
HDFS blocks locality index
- hdfsClientRetriesNumber - Static variable in class org.apache.hadoop.hbase.HBaseFileSystem
-
In order to handle NN connectivity hiccups, one need to retry non-idempotent operation at the
client level.
- 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
-
- HEADER - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
The first four bytes of Hadoop RPC connections
- HEADER - Static variable in class org.apache.hadoop.hbase.ipc.SecureServer
-
The first four bytes of secure RPC connections
- headerSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the size of this block header.
- headMap(byte[]) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- headMap(K) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- headSet(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- headSet(KeyValue, boolean) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- headSet(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- 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
-
- HealthCheckChore - Class in org.apache.hadoop.hbase
-
The Class HealthCheckChore for running health checker regularly.
- HealthCheckChore(int, Stoppable, Configuration) - Constructor for class org.apache.hadoop.hbase.HealthCheckChore
-
- heapSize() - Method in class org.apache.hadoop.hbase.client.Put
-
- HeapSize - Interface in org.apache.hadoop.hbase.io
-
Implementations can be asked for an estimate of their size in bytes.
- heapSize() - Method in interface org.apache.hadoop.hbase.io.HeapSize
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
Strings have two bytes per character due to default Java Unicode encoding
(hence length times 2).
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.CachedBlockQueue
-
Total size of all elements in this queue.
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
- heapSize() - Method in class org.apache.hadoop.hbase.KeyValue
-
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- heapSize - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
The precomputed heap size of this entry
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns the pre-computed and "deep" size of the Entry
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
The total memory usage of this map
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStore
-
Get the entire heap usage for this MemStore not including keys in the
snapshot.
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- HEAPSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- HFile - Class in org.apache.hadoop.hbase.io.hfile
-
File format for hbase.
- HFile() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile
-
- HFile.CachingBlockReader - Interface in org.apache.hadoop.hbase.io.hfile
-
An abstraction used by the block index
- HFile.Reader - Interface in org.apache.hadoop.hbase.io.hfile
-
An interface used by clients to open and iterate an
HFile
.
- HFile.Writer - Interface in org.apache.hadoop.hbase.io.hfile
-
API required to write an
HFile
- HFile.WriterFactory - Class in org.apache.hadoop.hbase.io.hfile
-
This variety of ways to construct writers is used throughout the code, and
we want to be able to swap writer implementations.
- 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
- HFILE_CACHE_REFRESH_PERIOD_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
Conf key for the frequency to attempt to refresh the cache of hfiles currently used in
snapshots (ms)
- HFILE_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
-
A non-capture group, for hfiles, so that this can be embedded.
- HFileArchiver - Class in org.apache.hadoop.hbase.backup
-
Utility class to handle the removal of HFiles (or the respective
StoreFiles
)
for a HRegion from the
FileSystem
.
- HFileArchiveUtil - Class in org.apache.hadoop.hbase.util
-
Helper class for all utilities related to archival/retrieval of HFiles
- HFileBlock - Class in org.apache.hadoop.hbase.io.hfile
-
Reading
HFile
version 1 and 2 blocks, and writing version 2 blocks.
- HFileBlock.BlockIterator - Interface in org.apache.hadoop.hbase.io.hfile
-
- HFileBlock.BlockWritable - Interface in org.apache.hadoop.hbase.io.hfile
-
Something that can be written into a block.
- HFileBlock.FSReader - Interface in org.apache.hadoop.hbase.io.hfile
-
A full-fledged reader with iteration ability.
- HFileBlock.Writer - Class in org.apache.hadoop.hbase.io.hfile
-
Unified version 2
HFile
block writer.
- HFileBlock.Writer(Compression.Algorithm, HFileDataBlockEncoder, boolean, int, ChecksumType, int) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- HFileBlockIndex - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileBlockIndex() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
- HFileBlockIndex.BlockIndexReader - Class in org.apache.hadoop.hbase.io.hfile
-
The reader will always hold the root level index in the memory.
- HFileBlockIndex.BlockIndexReader(RawComparator<byte[]>, int, HFile.CachingBlockReader) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- HFileBlockIndex.BlockIndexReader(RawComparator<byte[]>, int) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- HFileBlockIndex.BlockIndexWriter - Class in org.apache.hadoop.hbase.io.hfile
-
Writes the block index into the output stream.
- HFileBlockIndex.BlockIndexWriter() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Creates a single-level block index writer
- HFileBlockIndex.BlockIndexWriter(HFileBlock.Writer, BlockCache, String) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Creates a multi-level block index writer.
- HFileCleaner - Class in org.apache.hadoop.hbase.master.cleaner
-
This Chore, every time it runs, will clear the HFiles in the hfile archive
folder that are deletable for each HFile cleaner in the chain.
- HFileCleaner(int, Stoppable, Configuration, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- HFileCorruptionChecker - Class in org.apache.hadoop.hbase.util.hbck
-
This class marches through all of the region's hfiles and verifies that
they are all valid files.
- HFileCorruptionChecker(Configuration, ExecutorService, boolean) - Constructor for class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- HFileDataBlockEncoder - Interface in org.apache.hadoop.hbase.io.hfile
-
Controls what kind of data block encoding is used.
- HFileDataBlockEncoderImpl - Class in org.apache.hadoop.hbase.io.hfile
-
Do different kinds of data block encoding according to column family
options.
- HFileDataBlockEncoderImpl(DataBlockEncoding) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- HFileDataBlockEncoderImpl(DataBlockEncoding, DataBlockEncoding) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
Do data block encoding with specified options.
- HFileLink - Class in org.apache.hadoop.hbase.io
-
HFileLink describes a link to an hfile.
- HFileLink(Configuration, Path) - Constructor for class org.apache.hadoop.hbase.io.HFileLink
-
- HFileLink(Path, Path, Path) - Constructor for class org.apache.hadoop.hbase.io.HFileLink
-
- HFileLinkCleaner - Class in org.apache.hadoop.hbase.master.cleaner
-
HFileLink cleaner that determines if a hfile should be deleted.
- HFileLinkCleaner() - Constructor for class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
-
- HFileOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Writes HFiles.
- HFileOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
-
- hfilePattern - Static variable in class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
-
- 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
-
- HFileReaderV1 - Class in org.apache.hadoop.hbase.io.hfile
-
HFile
reader for version 1.
- HFileReaderV1(Path, FixedFileTrailer, FSDataInputStream, long, boolean, CacheConfig) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV1
-
Opens a HFile.
- HFileReaderV1.AbstractScannerV1 - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileReaderV1.AbstractScannerV1(HFileReaderV1, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.AbstractScannerV1
-
- HFileReaderV1.ScannerV1 - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileReaderV1.ScannerV1(HFileReaderV1, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.ScannerV1
-
- HFileReaderV2 - Class in org.apache.hadoop.hbase.io.hfile
-
HFile
reader for version 2.
- HFileReaderV2(Path, FixedFileTrailer, FSDataInputStream, FSDataInputStream, long, boolean, CacheConfig, DataBlockEncoding, HFileSystem) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
Opens a HFile.
- HFileReaderV2.AbstractScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileReaderV2.AbstractScannerV2(HFileReaderV2, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- HFileReaderV2.EncodedScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
-
ScannerV2 that operates on encoded data blocks.
- HFileReaderV2.EncodedScannerV2(HFileReaderV2, boolean, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- HFileReaderV2.ScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileReaderV2.ScannerV2(HFileReaderV2, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- HFileScanner - Interface in org.apache.hadoop.hbase.io.hfile
-
A scanner allows you to position yourself within a HFile and
scan through it.
- HFileSystem - Class in org.apache.hadoop.hbase.fs
-
An encapsulation for the FileSystem object that hbase uses to access
data.
- HFileSystem(Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.fs.HFileSystem
-
Create a FileSystem object for HBase regionservers.
- HFileSystem(FileSystem) - Constructor for class org.apache.hadoop.hbase.fs.HFileSystem
-
Wrap a FileSystem object within a HFileSystem.
- HFileWriterV1 - Class in org.apache.hadoop.hbase.io.hfile
-
Writes version 1 HFiles.
- HFileWriterV1(Configuration, CacheConfig, FileSystem, Path, FSDataOutputStream, int, Compression.Algorithm, HFileDataBlockEncoder, KeyValue.KeyComparator) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileWriterV1
-
Constructor that takes a path, creates and closes the output stream.
- HFileWriterV2 - Class in org.apache.hadoop.hbase.io.hfile
-
Writes HFile format version 2.
- HFileWriterV2(Configuration, CacheConfig, FileSystem, Path, FSDataOutputStream, int, Compression.Algorithm, HFileDataBlockEncoder, KeyValue.KeyComparator, ChecksumType, int, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
Constructor that takes a path, creates and closes the output stream.
- hflush() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- hfs - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
The filesystem used for accesing data
- HIGH_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- higher(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- highPriorityLevel - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- hint - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- HINT_LOOKAHEAD - Static variable in class org.apache.hadoop.hbase.client.Scan
-
EXPERT ONLY.
- hit(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- hlog - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- HLog - Class in org.apache.hadoop.hbase.regionserver.wal
-
HLog stores all the edits to the HStore.
- HLog(FileSystem, Path, Path, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Constructor.
- HLog(FileSystem, Path, Path, Configuration, List<WALActionsListener>, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Create an edit log at the given dir
location.
- HLog(FileSystem, Path, Path, Configuration, List<WALActionsListener>, boolean, String, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Create an edit log at the given dir
location.
- HLog.Entry - Class in org.apache.hadoop.hbase.regionserver.wal
-
Utility class that lets us keep track of the edit with it's key
Only used when splitting logs
- HLog.Entry() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
-
- HLog.Entry(HLogKey, WALEdit) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
-
Constructor for both params
- HLog.Metric - Class in org.apache.hadoop.hbase.regionserver.wal
-
- HLog.Metric() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLog.Metric
-
- HLog.Reader - Interface in org.apache.hadoop.hbase.regionserver.wal
-
- HLog.Writer - Interface in org.apache.hadoop.hbase.regionserver.wal
-
- hlogFileCount - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
Count of hlogfiles
- hlogFileSizeMB - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
the total size of hlog files in MB
- HLogFileSystem - Class in org.apache.hadoop.hbase.regionserver.wal
-
Acts as an abstraction between the HLog and the underlying filesystem.
- HLogFileSystem(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogFileSystem
-
In order to handle NN connectivity hiccups, one need to retry non-idempotent operation at the
client level.
- hlogForMeta - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- HLogInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
Simple
InputFormat
for
HLog
files.
- HLogInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
- HLogKey - Class in org.apache.hadoop.hbase.regionserver.wal
-
A Key for an entry in the change log.
- HLogKey() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Writable Constructor -- Do not use.
- HLogKey(byte[], byte[], long, long, UUID) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Create the log key!
We maintain the tablename mainly for debugging purposes.
- HLogLink - Class in org.apache.hadoop.hbase.io
-
HLogLink describes a link to a WAL.
- HLogLink(Configuration, String, String) - Constructor for class org.apache.hadoop.hbase.io.HLogLink
-
- HLogLink(Path, String, String) - Constructor for class org.apache.hadoop.hbase.io.HLogLink
-
- HLogLink(Path, Path) - Constructor for class org.apache.hadoop.hbase.io.HLogLink
-
- 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.
- HLogSplitter - Class in org.apache.hadoop.hbase.regionserver.wal
-
This class is responsible for splitting up a bunch of regionserver commit log
files that are no longer being written to, into new files, one per region for
region to replay on startup.
- HLogSplitter(Configuration, Path, Path, Path, FileSystem) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- HMaster - Class in org.apache.hadoop.hbase.master
-
HMaster is the "master server" for HBase.
- HMaster(Configuration) - Constructor for class org.apache.hadoop.hbase.master.HMaster
-
Initializes the HMaster.
- HMasterCommandLine - Class in org.apache.hadoop.hbase.master
-
- HMasterCommandLine(Class<? extends HMaster>) - Constructor for class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- HMasterCommandLine.LocalHMaster - Class in org.apache.hadoop.hbase.master
-
- HMasterCommandLine.LocalHMaster(Configuration) - Constructor for class org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
-
- HMasterInterface - Interface in org.apache.hadoop.hbase.ipc
-
Clients interact with the HMasterInterface to gain access to meta-level
HBase functionality, like finding an HRegionServer and creating/destroying
tables.
- HMasterRegionInterface - Interface in org.apache.hadoop.hbase.ipc
-
The Master publishes this Interface for RegionServers to register themselves
on.
- hostAddress - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- hostname - Variable in class org.apache.hadoop.hbase.avro.generated.AServerAddress
-
- HOSTNAME_PORT_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Addressing
-
- 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 - Class in org.apache.hadoop.hbase.regionserver
-
HRegion stores data for a certain region of a table.
- HRegion() - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
-
Should only be used for testing purposes
- HRegion(HRegion) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
-
HRegion copy constructor.
- HRegion(Path, HLog, FileSystem, Configuration, HRegionInfo, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
-
HRegion constructor.
- HRegion.BulkLoadListener - Interface in org.apache.hadoop.hbase.regionserver
-
Listener class to enable callers of
bulkLoadHFile() to perform any necessary
pre/post processing of a given bulkload call
- HRegion.FlushResult - Class in org.apache.hadoop.hbase.regionserver
-
Objects from this class are created when flushing to describe all the different states that
that method ends up in.
- HREGION_COMPACTIONDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used to construct the name of the compaction directory during compaction
- 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
Use '.' as a special character to seperate the log files from table data
- 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
- HRegionFileSystem - Class in org.apache.hadoop.hbase.regionserver
-
Acts as an abstraction layer b/w HBase and underlying fs.
- HRegionFileSystem(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- HRegionInfo - Class in org.apache.hadoop.hbase
-
HRegion information.
- HRegionInfo() - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Default constructor - creates empty object
- HRegionInfo(HRegionInfo090x) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Used only for migration
- HRegionInfo(byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
- HRegionInfo(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Construct HRegionInfo with explicit parameters
- HRegionInfo(byte[], byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Construct HRegionInfo with explicit parameters
- HRegionInfo(byte[], 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
- HRegionInfo090x - Class in org.apache.hadoop.hbase.migration
-
HRegion information.
- HRegionInfo090x() - Constructor for class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
Default constructor - creates empty object
- HRegionInfo090x(HTableDescriptor, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
Construct HRegionInfo with explicit parameters
- HRegionInfo090x(HTableDescriptor, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
Construct HRegionInfo with explicit parameters
- HRegionInfo090x(HTableDescriptor, byte[], byte[], boolean, long) - Constructor for class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
Construct HRegionInfo with explicit parameters
- HRegionInfo090x(HRegionInfo090x) - Constructor for class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
Costruct a copy of another HRegionInfo
- HRegionInterface - Interface in org.apache.hadoop.hbase.ipc
-
Clients interact with HRegionServers using a handle to the HRegionInterface.
- HRegionLocation - Class in org.apache.hadoop.hbase
-
Data structure to hold HRegionInfo and the address for the hosting
HRegionServer.
- HRegionLocation(HRegionInfo, String, int) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
-
Constructor
- 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
-
- HRegionServer - Class in org.apache.hadoop.hbase.regionserver
-
HRegionServer makes a set of HRegions available to clients.
- HRegionServer(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Starts a HRegionServer at the default location
- HRegionServerCommandLine - Class in org.apache.hadoop.hbase.regionserver
-
Class responsible for parsing the command line and starting the
RegionServer.
- HRegionServerCommandLine(Class<? extends HRegionServer>) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
-
- HRegionThriftServer - Class in org.apache.hadoop.hbase.regionserver
-
HRegionThriftServer - this class starts up a Thrift server in the same
JVM where the RegionServer is running.
- hrlToARL(HServerLoad.RegionLoad) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- hsaToASA(HServerAddress) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- HServerAddress - Class in org.apache.hadoop.hbase
-
- HServerAddress() - Constructor for class org.apache.hadoop.hbase.HServerAddress
-
Deprecated.
Constructor for deserialization use only.
- HServerAddress(InetSocketAddress) - Constructor for class org.apache.hadoop.hbase.HServerAddress
-
Deprecated.
- HServerAddress(String, int) - Constructor for class org.apache.hadoop.hbase.HServerAddress
-
Deprecated.
- HServerAddress(HServerAddress) - Constructor for class org.apache.hadoop.hbase.HServerAddress
-
Deprecated.
Copy-constructor.
- HServerInfo - Class in org.apache.hadoop.hbase
-
- HServerInfo() - Constructor for class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
- HServerInfo(HServerAddress, int) - Constructor for class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
Constructor that creates a HServerInfo with a generated startcode
- HServerInfo(HServerAddress, long, int) - Constructor for class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
- HServerInfo(HServerInfo) - Constructor for class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
Copy-constructor
- HServerLoad - Class in org.apache.hadoop.hbase
-
This class is used exporting current state of load on a RegionServer.
- HServerLoad() - Constructor for class org.apache.hadoop.hbase.HServerLoad
-
default constructor (used by Writable)
- HServerLoad(int, int, int, int, Map<byte[], HServerLoad.RegionLoad>, Set<String>) - Constructor for class org.apache.hadoop.hbase.HServerLoad
-
Constructor
- HServerLoad(HServerLoad) - Constructor for class org.apache.hadoop.hbase.HServerLoad
-
Constructor
- HServerLoad.RegionLoad - Class in org.apache.hadoop.hbase
-
Encapsulates per-region loading metrics.
- HServerLoad.RegionLoad() - Constructor for class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
Constructor, for Writable
- HServerLoad.RegionLoad(byte[], int, int, int, int, int, int, int, int, int, long, long, long, long) - Constructor for class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- hsiToASI(ServerName, HServerLoad) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- hslToASL(HServerLoad) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- HSnapshotDescription - Class in org.apache.hadoop.hbase.snapshot
-
Writable version of the SnapshotDescription used by the rpc
- HSnapshotDescription() - Constructor for class org.apache.hadoop.hbase.snapshot.HSnapshotDescription
-
- HSnapshotDescription(HBaseProtos.SnapshotDescription) - Constructor for class org.apache.hadoop.hbase.snapshot.HSnapshotDescription
-
- 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
- hsync() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- 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(byte[], 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(byte[], HConnection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- 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
.META.
- HTableDescriptor(byte[], HColumnDescriptor[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Private constructor used internally creating table descriptors for
catalog tables, .META.
and -ROOT-
.
- HTableDescriptor(byte[], HColumnDescriptor[], Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Private constructor used internally creating table descriptors for
catalog tables, .META.
and -ROOT-
.
- HTableDescriptor() - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Default constructor which constructs an empty object.
- HTableDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Construct a table descriptor specifying table name.
- HTableDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Construct a table descriptor specifying a byte array table name
- HTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Construct a table descriptor by cloning the descriptor passed as a parameter.
- hTableDescriptor - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- HTableFactory - Class in org.apache.hadoop.hbase.client
-
Factory for creating HTable instances.
- HTableFactory() - Constructor for class org.apache.hadoop.hbase.client.HTableFactory
-
- HTableInterface - Interface in org.apache.hadoop.hbase.client
-
Used to communicate with a single HBase table.
- HTableInterfaceFactory - Interface in org.apache.hadoop.hbase.client
-
Defines methods to create new HTableInterface.
- htablePool - Variable in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- HTablePool - Class in org.apache.hadoop.hbase.client
-
- HTablePool() - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Default Constructor.
- HTablePool(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Constructor to set maximum versions and use the specified configuration.
- HTablePool(Configuration, int, HTableInterfaceFactory) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Constructor to set maximum versions and use the specified configuration and
table factory.
- HTablePool(Configuration, int, PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Constructor to set maximum versions and use the specified configuration and
pool type.
- HTablePool(Configuration, int, HTableInterfaceFactory, PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Constructor to set maximum versions and use the specified configuration,
table factory and pool type.
- HTableUtil - Class in org.apache.hadoop.hbase.client
-
Utility class for HTable.
- HTableUtil() - Constructor for class org.apache.hadoop.hbase.client.HTableUtil
-
- htdToATD(HTableDescriptor) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- HThreadedSelectorServerArgs - Class in org.apache.hadoop.hbase.thrift
-
A TThreadedSelectorServer.Args that reads hadoop configuration
- HThreadedSelectorServerArgs(TNonblockingServerTransport, Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
- HttpServerUtil - Class in org.apache.hadoop.hbase.util
-
HttpServer utility.
- HttpServerUtil() - Constructor for class org.apache.hadoop.hbase.util.HttpServerUtil
-
- humanReadableTimestamp(long) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- I - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'I'
- ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- ia - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- ia - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
if the scannerId is invalid
- ia - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
if the scannerId is invalid
- id - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- id - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
id of a scanner returned by scannerOpen
- id - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
id of a scanner returned by scannerOpen
- id - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
id of a scanner returned by scannerOpen
- id - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- ID_ATRIBUTE - Static variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- ID_SIZE - Static variable in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- idealMaxKeys(long, double) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
The maximum number of keys we can put into a Bloom filter of a certain
size to maintain the given error rate, assuming the number of hash
functions is chosen optimally and does not even have to be an integer
(hence the "ideal" in the function name).
- 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
-
- IdLock - Class in org.apache.hadoop.hbase.util
-
Allows multiple concurrent clients to lock on a numeric id with a minimal
memory overhead.
- IdLock() - Constructor for class org.apache.hadoop.hbase.util.IdLock
-
- IdLock.Entry - Class in org.apache.hadoop.hbase.util
-
An entry returned to the client as a lock object
- ignoreZKDeleteForTesting - Variable in class org.apache.hadoop.hbase.master.SplitLogManager
-
- IllegalArgument - Exception in org.apache.hadoop.hbase.thrift.generated
-
An IllegalArgument exception indicates an illegal or invalid
argument was passed into a procedure.
- IllegalArgument() - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- IllegalArgument(String) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- IllegalArgument(IllegalArgument) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
Performs a deep copy on other.
- IllegalArgument._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- immediateAssignment(List<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.DefaultLoadBalancer
-
Generates an immediate assignment plan to be used by a new master for
regions in transition that do not have an already known destination.
- immediateAssignment(List<HRegionInfo>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Sync assign a region
- 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
- ImmutableBytesWritable.Comparator - Class in org.apache.hadoop.hbase.io
-
A Comparator optimized for ImmutableBytesWritable.
- ImmutableBytesWritable.Comparator() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
-
constructor
- impl - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
The coprocessor
- implies(Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- implies(byte[], byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
Checks that a given table operation is authorized by this permission
instance.
- implies(byte[], KeyValue, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
Checks if this permission grants access to perform the given action on
the given table and key value.
- 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 - Variable in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- in - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- inc(String, int) - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- inc(int) - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
-
- inc() - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
-
- inc(int, long) - Method in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
-
Increment the metrics for numOps operations
- inc(long) - Method in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
-
Increment the metrics for numOps operations
- includeMVCCReadpoint - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- includeMVCCReadpoint(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- includeMVCCReadpoint(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- 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.
- includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Check if the range has any overlap with TimeRange
- includeTable(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- includeTimestamp(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Update the current TimestampRange to include the timestamp from KeyValue
If the Key is of type DeleteColumn or DeleteFamily, it includes the
entire time range from 0 to timestamp of the key.
- includeTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Update the current TimestampRange to include the timestamp from Key.
- InclusiveStopFilter - Class in org.apache.hadoop.hbase.filter
-
A Filter that stops after the given row.
- InclusiveStopFilter() - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- InclusiveStopFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- incMethodTime(String, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- incNumRowKeysInBatchGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- incNumRowKeysInBatchMutate(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- 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
- increase(long) - Method in class org.apache.hadoop.hbase.util.SizeBasedThrottler
-
Blocks until internal counter is lower than threshold
and then increases value of internal counter.
- IncreasingToUpperBoundRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
Split size is the number of regions that are on this server that all are
of the same table, cubed, times 2x the region flush size OR the maximum
region split size, whichever is smaller.
- IncreasingToUpperBoundRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- increment(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- increment(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- increment(Increment) - Method in class org.apache.hadoop.hbase.client.HTable
-
Increments one or more columns within a single row.
- increment(Increment) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Increments one or more columns within a single row.
- Increment - Class in org.apache.hadoop.hbase.client
-
Used to perform Increment operations on a single row.
- Increment() - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Constructor for Writable.
- Increment(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Create a Increment operation for the specified row.
- Increment(byte[], RowLock) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
- increment(S) - Method in interface org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- increment(byte[], Increment) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Increments one or more columns values in a row.
- increment() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Increment the current version count
- increment(Increment, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Perform one or more increment operations on a row.
- increment(Increment, Integer, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
row locks (lockId) held outside the extent of the operation are deprecated.
- increment(byte[], Increment) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- increment(Increment) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- increment(TIncrement, AsyncMethodCallback<Hbase.AsyncClient.increment_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- increment(TIncrement, AsyncMethodCallback<Hbase.AsyncClient.increment_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- increment(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- increment(TIncrement) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Increment a cell by the ammount.
- increment - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
The single increment to apply
- increment(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- increment(ByteBuffer, TIncrement, AsyncMethodCallback<THBaseService.AsyncClient.increment_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- increment(ByteBuffer, TIncrement, AsyncMethodCallback<THBaseService.AsyncClient.increment_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- increment(ByteBuffer, TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- increment(ByteBuffer, TIncrement) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
- increment - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
the TIncrement to increment
- increment(ByteBuffer, TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- incrementBlocks() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
Increments the number of blocks in the cache for this entry
- 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.
- IncrementCoalescer - Class in org.apache.hadoop.hbase.thrift
-
This class will coalesce increments from a thift server if
hbase.regionserver.thrift.coalesceIncrement is set to true.
- IncrementCoalescer(ThriftServerRunner.HBaseHandler) - Constructor for class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- IncrementCoalescerMBean - Interface in org.apache.hadoop.hbase.thrift
-
- incrementColumnValue(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, long, boolean) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- incrementColumnValue(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, long, boolean, Callback<Long>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- incrementColumnValue(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, long, boolean) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], long, boolean) - 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
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], byte[], long, boolean) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- incrementColumnValue(byte[], byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], long) - 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
-
- incrementFailedDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- incrementFailedGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- incrementFailedPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- incrementFromThrift(TIncrement) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
- incrementFromThrift(TIncrement) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- incrementHeapSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- IncrementingEnvironmentEdge - Class in org.apache.hadoop.hbase.util
-
Uses an incrementing algorithm instead of the default.
- IncrementingEnvironmentEdge() - Constructor for class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
-
- incrementRequests(int) - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
-
- incrementRequests(int) - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- incrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- incrementRows(List<TIncrement>, AsyncMethodCallback<Hbase.AsyncClient.incrementRows_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- incrementRows(List<TIncrement>, AsyncMethodCallback<Hbase.AsyncClient.incrementRows_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- incrementRows(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- incrementRows(List<TIncrement>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
- incrementRows(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- increments - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
The list of increments
- incrementSplitFailureCount() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- incrementSplitSuccessCount() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- incrementSucessfulDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- incrementSucessfulGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- incrementSucessfulPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- incrNumericMetric(String, long) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
- incrNumericPersistentMetric(String, long) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
- incRpcCount() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- incrTimeVaryingMetric(String, long) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
- incrTimeVaryingMetric(String, long, int) - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerDynamicMetrics
-
- incTimeInQueue(long) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- incValue(long) - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- index - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.ParallelCall
-
- indexSize() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- indexSize() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- indexSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- inetSocketAddress - Variable in class org.apache.hadoop.hbase.avro.generated.AServerAddress
-
- inferBoundaries(TreeMap<byte[], Integer>) - Static method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- infoPort - Variable in class org.apache.hadoop.hbase.avro.generated.AServerInfo
-
- INFOPORT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- InfoServer - Class in org.apache.hadoop.hbase.util
-
Create a Jetty embedded server to answer http requests.
- InfoServer(String, String, int, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.util.InfoServer
-
Create a status server on the given port.
- init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Build the scanner.
- init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
Build the scanner.
- init(HMaster) - Static method in class org.apache.hadoop.hbase.master.MXBeanImpl
-
- init(String, ContextFactory) - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
-
- init() - Static method in class org.apache.hadoop.hbase.metrics.HBaseInfo
-
- init() - Method in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
-
- init(HRegionServer) - Static method in class org.apache.hadoop.hbase.regionserver.MXBeanImpl
-
- init(FileSystem, Path, Configuration) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Reader
-
- init(FileSystem, Path, Configuration) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Writer
-
- init(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- init(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
-
- init(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEditCodec
-
Initialize this - called exactly once after the object is instantiated and before any
other method in this class.
- init(Configuration, FileSystem, ReplicationSourceManager, Stoppable, AtomicBoolean, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Instantiation method used by region servers
- init(Configuration, FileSystem, ReplicationSourceManager, Stoppable, AtomicBoolean, String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Initializer for the source
- init() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Adds a normal source per registered peer cluster and tries to process all
old region server hlog queues
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
-
- init(Configuration, ServiceAuthorizationManager) - Static method in class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- init(Configuration) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- 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.
- initialChore() - Method in class org.apache.hadoop.hbase.Chore
-
Override to run a task before we start looping.
- 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.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionRecordReader
-
- initialize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Initialize this region.
- initialize(CancelableProgressable) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Initialize this region.
- initialize(long) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Initializes the memstoreRead/Write points appropriately.
- initialize(Server, FileSystem, Path, Path) - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Initializes the replication service object.
- initialize(Server, FileSystem, Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- 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<? extends WritableComparable>, Class<? extends Writable>, 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<? extends WritableComparable>, Class<? extends Writable>, JobConf, boolean) - 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<? extends WritableComparable>, Class<? extends Writable>, 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<? extends WritableComparable>, Class<? extends Writable>, 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<? extends WritableComparable>, Class<? extends Writable>, 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<? extends WritableComparable>, Class<? extends Writable>, 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<? extends WritableComparable>, Class<? extends Writable>, 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<? extends WritableComparable>, Class<? extends Writable>, 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.
- 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.
- 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.
- injectEdge(EnvironmentEdge) - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
Injects the given edge such that it becomes the managed entity.
- InlineBlockWriter - Interface in org.apache.hadoop.hbase.io.hfile
-
A way to write "inline" blocks into an
HFile
.
- inMemory - Variable in class org.apache.hadoop.hbase.avro.generated.AFamilyDescriptor
-
- inMemory - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- INMEMORY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- INPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Job parameter that specifies the input table.
- InputSampler<K,V> - Class in org.apache.hadoop.hbase.mapreduce.hadoopbackport
-
- InputSampler(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.hadoopbackport.InputSampler
-
- InputSampler.IntervalSampler<K,V> - Class in org.apache.hadoop.hbase.mapreduce.hadoopbackport
-
Sample from s splits at regular intervals.
- InputSampler.IntervalSampler(double) - Constructor for class org.apache.hadoop.hbase.mapreduce.hadoopbackport.InputSampler.IntervalSampler
-
Create a new IntervalSampler sampling all splits.
- InputSampler.IntervalSampler(double, int) - Constructor for class org.apache.hadoop.hbase.mapreduce.hadoopbackport.InputSampler.IntervalSampler
-
Create a new IntervalSampler.
- InputSampler.RandomSampler<K,V> - Class in org.apache.hadoop.hbase.mapreduce.hadoopbackport
-
Sample from random points in the input.
- InputSampler.RandomSampler(double, int) - Constructor for class org.apache.hadoop.hbase.mapreduce.hadoopbackport.InputSampler.RandomSampler
-
Create a new RandomSampler sampling all splits.
- InputSampler.RandomSampler(double, int, int) - Constructor for class org.apache.hadoop.hbase.mapreduce.hadoopbackport.InputSampler.RandomSampler
-
Create a new RandomSampler.
- InputSampler.Sampler<K,V> - Interface in org.apache.hadoop.hbase.mapreduce.hadoopbackport
-
Interface to sample using an
InputFormat
.
- InputSampler.SplitSampler<K,V> - Class in org.apache.hadoop.hbase.mapreduce.hadoopbackport
-
Samples the first n records from s splits.
- InputSampler.SplitSampler(int) - Constructor for class org.apache.hadoop.hbase.mapreduce.hadoopbackport.InputSampler.SplitSampler
-
Create a SplitSampler sampling all splits.
- InputSampler.SplitSampler(int, int) - Constructor for class org.apache.hadoop.hbase.mapreduce.hadoopbackport.InputSampler.SplitSampler
-
Create a new SplitSampler.
- INSECURE_VERSIONS - Static variable in class org.apache.hadoop.hbase.ipc.SecureServer
-
- insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
The implementation of this method should act with the assumption that the barrier condition
has been satisfied.
- insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- insideBarrier() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
do a flush snapshot of every region on this rs from the target table.
- install(Configuration, FileSystem, Stoppable, Thread) - Static method in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
Install a shutdown hook that calls stop on the passed Stoppable
and then thread joins against the passed threadToJoin
.
- instance - Static variable in class org.apache.hadoop.hbase.EmptyWatcher
-
- instance - Variable in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.client.UserProvider
-
- instantiateHLog(Path, Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- instantiateHStore(Path, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- instantiateRegionScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- INTEGER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for an Integer
- internalFlushcache(MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Flush the memstore.
- internalFlushcache(HLog, long, MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- InternalScanner - Interface in org.apache.hadoop.hbase.regionserver
-
Internal scanners differ from client-side scanners in that they operate on
HStoreKeys and byte[] instead of RowResults.
- interrupt() - Method in class org.apache.hadoop.hbase.util.HasThread
-
- interruptedException(InterruptedException) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Handles InterruptedExceptions in client calls.
- intervalHeartBeat() - Method in class org.apache.hadoop.hbase.metrics.MetricsRate
-
- 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.
- InvalidHFileException - Exception in org.apache.hadoop.hbase.io.hfile
-
Thrown when an invalid HFile format is detected
- InvalidHFileException() - Constructor for exception org.apache.hadoop.hbase.io.hfile.InvalidHFileException
-
constructor
- InvalidHFileException(String) - Constructor for exception org.apache.hadoop.hbase.io.hfile.InvalidHFileException
-
Constructor
- 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
- Invocation - Class in org.apache.hadoop.hbase.ipc
-
A method invocation, including the method name and its parameters.
- Invocation() - Constructor for class org.apache.hadoop.hbase.ipc.Invocation
-
- Invocation(Method, Class<? extends VersionedProtocol>, Object[]) - Constructor for class org.apache.hadoop.hbase.ipc.Invocation
-
- invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hbase.ipc.ExecRPCInvoker
-
- invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hbase.ipc.MasterExecRPCInvoker
-
- invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- IO_STOREFILE_BLOOM_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Target Bloom block size.
- IO_STOREFILE_BLOOM_ENABLED - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Master switch to enable Bloom filters
- IO_STOREFILE_BLOOM_ERROR_RATE - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Specifies the target error rate to use when selecting the number of keys
per Bloom filter.
- IO_STOREFILE_BLOOM_MAX_FOLD - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Maximum folding factor allowed.
- IO_STOREFILE_BLOOM_MAX_KEYS - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
For default (single-block) Bloom filters this specifies the maximum number
of keys.
- IO_STOREFILE_DELETEFAMILY_BLOOM_ENABLED - Static variable in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Master switch to enable Delete Family Bloom filters
- IOError - Exception in org.apache.hadoop.hbase.thrift.generated
-
An IOError exception signals that an error occurred communicating
to the Hbase master or an Hbase region server.
- IOError() - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- IOError(String) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- IOError(IOError) - Constructor for exception org.apache.hadoop.hbase.thrift.generated.IOError
-
Performs a deep copy on other.
- IOError._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_DEFAULT - Static variable in class org.apache.hadoop.hbase.ipc.SecureClient
-
- IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_KEY - Static variable in class org.apache.hadoop.hbase.ipc.SecureClient
-
- is32BitJVM() - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Determines if we are running in a 32-bit JVM.
- 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
.META.
- IS_ROOT - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by rest interface to access this metadata
attribute which denotes if the table is a -ROOT- region or not
- isAborted() - Method in interface org.apache.hadoop.hbase.Abortable
-
Check if the server or client was aborted.
- isAborted() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isAborted() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- isAborted() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isAborted() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- isAborted() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
-
- isAborted() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- isAbortPathNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Is this in the procedure barrier abort znode path
- isActiveMaster() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- isActiveMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master is currently the active master or not.
- isAlive() - Method in class org.apache.hadoop.hbase.util.HasThread
-
- isAppendSupported(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Heuristic to determine whether is safe or not to open a file for append
Looks both for dfs.support.append and use reflection to search
for SequenceFile.Writer.syncFs() or FSDataOutputStream.hflush()
- 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
-
- isAvailable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isBackReferencesDir(Path) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
Checks if the specified directory path is a back reference links folder.
- isBadJvmVersion() - Static method in class org.apache.hadoop.hbase.util.JvmVersion
-
Return true if the current JVM is known to be unstable.
- isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Checks whether the block cache is enabled.
- isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- isCarryingMeta(ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- isCarryingRegion(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Check if the shutdown server carries the specific region.
- isCarryingRoot(ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- isClassExempt(String) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
Determines whether the given class should be exempt from being loaded
by this ClassLoader.
- isClosed() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isClosed() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- isClosed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isClosing() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- isClosing() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isClusterShutdown() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- isClusterUp() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Checks if cluster is up.
- isColumnSorted() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.ResultScannerWrapper
-
- isCompaction - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- isCompactionNeeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResult
-
Convenience method, the equivalent of checking if result is FLUSHED_COMPACTION_NEEDED.
- isCorrectEncoder(DataBlockEncoder, short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Check if given encoder has this id.
- isCorrupted(Path, String, FileSystem) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- isData() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- isDeadServer(String) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- isDeferredLogFlush() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if deferred log edits are enabled on the table.
- isDelayed() - Method in interface org.apache.hadoop.hbase.ipc.Delayable
-
- isDelayed() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- isDelete(byte) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- isDelete() - Method in class org.apache.hadoop.hbase.KeyValue
-
- isDelete - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- isDeleteColumnOrFamily() - Method in class org.apache.hadoop.hbase.KeyValue
-
- isDeleted(byte[], int, int, long) - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
-
Check if the specified KeyValue buffer has been deleted by a previously
seen delete.
- isDeleted(byte[], int, int, long) - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
Check if the specified KeyValue buffer has been deleted by a previously
seen delete.
- isDeleteFamily() - Method in class org.apache.hadoop.hbase.KeyValue
-
- isDeleteFamilyBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- isDeleteType() - Method in class org.apache.hadoop.hbase.KeyValue
-
- isDisabledOrEnablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isDisabledTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isDisabledTable(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
-
- isDisablingOrDisabledTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isDisablingOrDisabledTable(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
-
- isDisablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isDone(long) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Give the tracker a chance to declare it's done based on only the timestamp
to allow an early out.
- isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
- isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
- isEmpty() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method to check if the familyMap is empty
- isEmpty() - Method in class org.apache.hadoop.hbase.client.Result
-
Check if the underlying KeyValue [] is empty or not
- isEmpty() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- isEmpty() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- isEmpty() - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
-
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Checks whether the map is currently empty.
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- isEmpty() - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
- isEmpty() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- isEmpty() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- isEmpty() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- isEmpty() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- isEmpty() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
- isEmptyColumn() - Method in class org.apache.hadoop.hbase.KeyValue
-
- isEnabledOrDisablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isEnabledTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isEnabledTable(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableReadOnly
-
- isEnablingOrEnabledTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isEnablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
- isError - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- isEventBeingHandled - Variable in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- isExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Calls fs.exists().
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Check that given column family is essential for filter to check row.
- isFamilyEssential(Filter, byte[]) - Static method in class org.apache.hadoop.hbase.filter.FilterBase
-
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
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
-
Should the master delete the file or keep it?
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- isFileInfoLoaded() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- isFileInfoLoaded() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1
-
- isFileInfoLoaded() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- isFileScanner() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
- isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- isFilterDone() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- isFinished() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- isFinished() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- isFinished() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- isFinished() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Check to see if the snapshot is finished, where finished may be success or failure.
- isFlushSucceeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResult
-
Convenience method, the equivalent of checking if result is
FLUSHED_NO_COMPACTION_NEEDED or FLUSHED_NO_COMPACTION_NEEDED.
- isGeneralBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- isGetScan() - Method in class org.apache.hadoop.hbase.client.Scan
-
- isGlobal() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
Returns true if this permission describes a global user permission.
- isGroupPrincipal(String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Returns whether or not the given name should be interpreted as a group
principal.
- isHadoopSecurityEnabled() - Method in class org.apache.hadoop.hbase.client.UserProvider
-
- isHBaseSecurityEnabled() - Method in class org.apache.hadoop.hbase.client.UserProvider
-
- isHBaseSecurityEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.security.User
-
Returns whether or not secure authentication is enabled for HBase.
- isHDFS(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- isHFileLink(Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
- isHFileLink(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
- isInitializationStartsMetaRegoinAssignment() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master has started initialization and is about to do meta region assignment
- isInitialized() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master has completed with its initialization and is
ready.
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- isInMemory() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isInMemory() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- isInMemory() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- isInRequest() - Method in class org.apache.hadoop.hbase.ipc.RequestContext
-
- isInRequestContext() - Static method in class org.apache.hadoop.hbase.ipc.RequestContext
-
Indicates whether or not the current thread is within scope of executing
an RPC request.
- isInternal() - Method in class org.apache.hadoop.hbase.KeyValue
-
- isInterrupted() - Method in class org.apache.hadoop.hbase.util.HasThread
-
- isIsDelete() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- isLatestTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
-
- isLegalFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isLegalTableName(byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
- isLegalTableName(byte[], boolean) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check passed byte buffer, "tableName", is legal user-space table name.
- isLoadingCfsOnDemandDefault() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isLocal(Configuration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- isLocationAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.RootRegionTracker
-
Checks if the root region location is available.
- isLogDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate
-
Deprecated.
- isLogDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- isLogDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
- isLowReplicationRollEnabled() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Get LowReplication-Roller status
- isMajor() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- isMajorCompacted(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the hbase rootdir and checks all stores have only
one file in them -- that is, they've been major compacted.
- isMajorCompactedPre020(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the hbase rootdir and checks all stores have only
one file in them -- that is, they've been major compacted.
- isMaster() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- isMasterRunning() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isMasterRunning() - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
- isMasterRunning() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- isMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- isMetaFamily(byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- isMetaFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- isMetaHRIUpdated(MasterServices) - Static method in class org.apache.hadoop.hbase.catalog.MetaMigrationRemovingHTD
-
Deprecated.
- isMetaRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isMetaRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Checks if this table is either -ROOT-
or .META.
- isMetaRegion() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- isMetaTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isMetaTable() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Checks if the table is a .META.
table
- isMetaTable(byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
Checks of the tableName being passed represents either
-ROOT-
or .META.
- isMetaTable() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- isMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- isOffline() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isOffline() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- isOffline() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- isOffPeakCompaction() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactSelection
-
- IsolationLevel - Enum in org.apache.hadoop.hbase.client
-
Specify Isolation levels in Scan operations.
- isOnline - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Report the status of the server.
- isOnlineSchemaChangeSupported() - Method in enum org.apache.hadoop.hbase.executor.EventHandler.EventType
-
- isOpened() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- isOpening() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- isOperationRunning() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- isOperationRunning() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Indicates to the client whether this task is monitoring a currently active
RPC call to a database command.
- isPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- isPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
check whether the peer is enabled or not
- isPendingClose() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- isPendingOpen() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- isPre020FileLayout(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Expects to find -ROOT- directory.
- 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
-
- isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.consumer.ProtobufMessageBodyConsumer
-
- 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
-
- isReference(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- isReference(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- isRegionAssigned(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Checks whether the region is assigned.
- isRegionInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- isRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- 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.
- isReplication(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- isRescanNode(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- isReservedFileInfoKey(byte[]) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Return true if the given file info key is reserved for internal use.
- isRestoreDone(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Returns the status of a restore operation.
- isRestoreSnapshotDone(HSnapshotDescription) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
- isRestoreSnapshotDone(HSnapshotDescription) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Returns the status of the requested snapshot restore/clone operation.
- isReturnResults() - Method in class org.apache.hadoop.hbase.client.Append
-
- isReturnValueDelayed() - Method in interface org.apache.hadoop.hbase.ipc.Delayable
-
- isReturnValueDelayed() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- isRootRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isRootRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the descriptor represents a -ROOT-
region.
- isRootRegion() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- isRPCRunning() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- isRPCRunning() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Indicates to the client whether this task is monitoring a currently active
RPC call.
- isSameHdfs(Configuration, FileSystem, FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSHDFSUtils
-
- isSameHostnameAndPort(ServerName, ServerName) - Static method in class org.apache.hadoop.hbase.ServerName
-
- isSchemaConfigured() - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
- isSecureZooKeeper(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Returns whether or not secure authentication is enabled
(whether hbase.security.authentication
is set to
kerberos
.
- isSecurityEnabled() - Static method in class org.apache.hadoop.hbase.security.User
-
Returns whether or not Kerberos authentication is configured for Hadoop.
- isSecurityEnabled() - Static method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
Returns the result of UserGroupInformation.isSecurityEnabled()
.
- isSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- isSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- isSeeked() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- isServerOnline(ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Check whether the RegionServer is online.
- isServerOnline(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- isServerShutdownHandlerEnabled() - Method in class org.apache.hadoop.hbase.master.HMaster
-
ServerShutdownHandlerEnabled is set false before completing
assignRootAndMeta to prevent processing of ServerShutdownHandler.
- isServerShutdownHandlerEnabled() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- isSet(AlreadyExists._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(BatchMutation._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ColumnDescriptor._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.atomicIncrement_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.atomicIncrement_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.compact_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.compact_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.createTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.createTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.deleteAll_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.deleteAll_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.deleteAllRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.deleteAllRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.deleteAllRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.deleteAllRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.deleteAllTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.deleteAllTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.deleteTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.deleteTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.disableTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.disableTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.enableTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.enableTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.get_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.get_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getColumnDescriptors_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getColumnDescriptors_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRegionInfo_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRegionInfo_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowOrBefore_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowOrBefore_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowsWithColumns_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowsWithColumns_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowsWithColumnsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowsWithColumnsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowWithColumns_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowWithColumns_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowWithColumnsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getRowWithColumnsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getTableNames_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getTableNames_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getTableRegions_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getTableRegions_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getVer_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getVer_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getVerTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.getVerTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.increment_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.increment_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.incrementRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.incrementRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.isTableEnabled_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.isTableEnabled_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.majorCompact_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.majorCompact_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.mutateRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.mutateRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.mutateRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.mutateRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.mutateRowsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.mutateRowsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.mutateRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.mutateRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerClose_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerClose_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerGet_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerGet_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerGetList_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerGetList_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerOpen_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerOpen_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerOpenTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerOpenTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerOpenWithPrefix_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerOpenWithPrefix_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerOpenWithScan_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerOpenWithScan_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerOpenWithStop_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerOpenWithStop_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerOpenWithStopTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.scannerOpenWithStopTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(IllegalArgument._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(IOError._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Mutation._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TCell._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TColumn._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TRegionInfo._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TRowResult._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TScan._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TColumn._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TColumnIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TColumnValue._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TDelete._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TGet._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.checkAndDelete_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.checkAndDelete_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.checkAndPut_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.checkAndPut_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.closeScanner_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.closeScanner_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.deleteMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.deleteMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.deleteSingle_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.deleteSingle_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.exists_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.exists_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.get_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.get_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.getMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.getMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.getScannerResults_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.getScannerResults_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.getScannerRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.getScannerRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.increment_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.increment_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.mutateRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.mutateRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.openScanner_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.openScanner_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.put_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.put_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.putMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.putMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TIllegalArgument._Fields) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TIOError._Fields) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TPut._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TResult._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TRowMutations._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TScan._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TTimeRange._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSetAmmount() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
Returns true if field ammount is set (has been assigned a value) and false otherwise
- isSetAmount() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
Returns true if field amount is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Returns true if field attributes is set (has been assigned a value) and false otherwise
- isSetBatchSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Returns true if field batchSize is set (has been assigned a value) and false otherwise
- isSetBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
Returns true if field blockCacheEnabled is set (has been assigned a value) and false otherwise
- isSetBloomFilterNbHashes() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
Returns true if field bloomFilterNbHashes is set (has been assigned a value) and false otherwise
- isSetBloomFilterType() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
Returns true if field bloomFilterType is set (has been assigned a value) and false otherwise
- isSetBloomFilterVectorSize() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
Returns true if field bloomFilterVectorSize is set (has been assigned a value) and false otherwise
- isSetCaching() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
Returns true if field caching is set (has been assigned a value) and false otherwise
- isSetCaching() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Returns true if field caching is set (has been assigned a value) and false otherwise
- isSetCell() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
Returns true if field cell is set (has been assigned a value) and false otherwise
- isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
Returns true if field column is set (has been assigned a value) and false otherwise
- isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Returns true if field column is set (has been assigned a value) and false otherwise
- isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Returns true if field column is set (has been assigned a value) and false otherwise
- isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Returns true if field column is set (has been assigned a value) and false otherwise
- isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Returns true if field column is set (has been assigned a value) and false otherwise
- isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Returns true if field column is set (has been assigned a value) and false otherwise
- isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
Returns true if field column is set (has been assigned a value) and false otherwise
- isSetColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
Returns true if field column is set (has been assigned a value) and false otherwise
- isSetColumnFamilies() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
Returns true if field columnFamilies is set (has been assigned a value) and false otherwise
- isSetColumnName() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
Returns true if field columnName is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumnValues() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
Returns true if field columnValues is set (has been assigned a value) and false otherwise
- isSetColumnValues() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
Returns true if field columnValues is set (has been assigned a value) and false otherwise
- isSetCompression() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
Returns true if field compression is set (has been assigned a value) and false otherwise
- isSetDeletes() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
Returns true if field deletes is set (has been assigned a value) and false otherwise
- isSetDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
Returns true if field deleteSingle is set (has been assigned a value) and false otherwise
- isSetDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
Returns true if field deleteSingle is set (has been assigned a value) and false otherwise
- isSetDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- isSetDeleteType() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
Returns true if field deleteType is set (has been assigned a value) and false otherwise
- isSetDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
Returns true if field durability is set (has been assigned a value) and false otherwise
- isSetDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
Returns true if field durability is set (has been assigned a value) and false otherwise
- isSetEndKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
Returns true if field endKey is set (has been assigned a value) and false otherwise
- isSetExist() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
Returns true if field exist is set (has been assigned a value) and false otherwise
- isSetFamily() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
Returns true if field family is set (has been assigned a value) and false otherwise
- isSetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
Returns true if field family is set (has been assigned a value) and false otherwise
- isSetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
Returns true if field family is set (has been assigned a value) and false otherwise
- isSetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
Returns true if field family is set (has been assigned a value) and false otherwise
- isSetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
Returns true if field family is set (has been assigned a value) and false otherwise
- isSetFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
Returns true if field family is set (has been assigned a value) and false otherwise
- isSetFilterString() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
Returns true if field filterString is set (has been assigned a value) and false otherwise
- isSetFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
Returns true if field filterString is set (has been assigned a value) and false otherwise
- isSetFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Returns true if field filterString is set (has been assigned a value) and false otherwise
- isSetGet() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
Returns true if field get is set (has been assigned a value) and false otherwise
- isSetGet() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
Returns true if field get is set (has been assigned a value) and false otherwise
- isSetGets() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
Returns true if field gets is set (has been assigned a value) and false otherwise
- isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
Returns true if field ia is set (has been assigned a value) and false otherwise
- isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
Returns true if field ia is set (has been assigned a value) and false otherwise
- isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
Returns true if field ia is set (has been assigned a value) and false otherwise
- isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
Returns true if field ia is set (has been assigned a value) and false otherwise
- isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
Returns true if field ia is set (has been assigned a value) and false otherwise
- isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
Returns true if field ia is set (has been assigned a value) and false otherwise
- isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
Returns true if field ia is set (has been assigned a value) and false otherwise
- isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
Returns true if field ia is set (has been assigned a value) and false otherwise
- isSetIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
Returns true if field ia is set (has been assigned a value) and false otherwise
- isSetIa() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
Returns true if field ia is set (has been assigned a value) and false otherwise
- isSetIa() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
Returns true if field ia is set (has been assigned a value) and false otherwise
- isSetId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- isSetId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- isSetId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
Returns true if field id is set (has been assigned a value) and false otherwise
- isSetId() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
Returns true if field id is set (has been assigned a value) and false otherwise
- isSetIncrement() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
Returns true if field increment is set (has been assigned a value) and false otherwise
- isSetIncrement() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
Returns true if field increment is set (has been assigned a value) and false otherwise
- isSetIncrements() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
Returns true if field increments is set (has been assigned a value) and false otherwise
- isSetInMemory() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
Returns true if field inMemory is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
Returns true if field io is set (has been assigned a value) and false otherwise
- isSetIsDelete() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
Returns true if field isDelete is set (has been assigned a value) and false otherwise
- isSetMaxStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
Returns true if field maxStamp is set (has been assigned a value) and false otherwise
- isSetMaxVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
Returns true if field maxVersions is set (has been assigned a value) and false otherwise
- isSetMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
Returns true if field maxVersions is set (has been assigned a value) and false otherwise
- isSetMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Returns true if field maxVersions is set (has been assigned a value) and false otherwise
- isSetMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
Returns true if field message is set (has been assigned a value) and false otherwise
- isSetMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
Returns true if field message is set (has been assigned a value) and false otherwise
- isSetMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
Returns true if field message is set (has been assigned a value) and false otherwise
- isSetMessage() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
Returns true if field message is set (has been assigned a value) and false otherwise
- isSetMessage() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
Returns true if field message is set (has been assigned a value) and false otherwise
- isSetMinStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
Returns true if field minStamp is set (has been assigned a value) and false otherwise
- isSetMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
Returns true if field mutations is set (has been assigned a value) and false otherwise
- isSetMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Returns true if field mutations is set (has been assigned a value) and false otherwise
- isSetMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Returns true if field mutations is set (has been assigned a value) and false otherwise
- isSetMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
Returns true if field mutations is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetNbRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
Returns true if field nbRows is set (has been assigned a value) and false otherwise
- isSetNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
Returns true if field numRows is set (has been assigned a value) and false otherwise
- isSetNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
Returns true if field numRows is set (has been assigned a value) and false otherwise
- isSetNumVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Returns true if field numVersions is set (has been assigned a value) and false otherwise
- isSetNumVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Returns true if field numVersions is set (has been assigned a value) and false otherwise
- isSetPort() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
Returns true if field port is set (has been assigned a value) and false otherwise
- isSetPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
Returns true if field put is set (has been assigned a value) and false otherwise
- isSetPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
Returns true if field put is set (has been assigned a value) and false otherwise
- isSetPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- isSetPuts() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
Returns true if field puts is set (has been assigned a value) and false otherwise
- isSetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
Returns true if field qualifier is set (has been assigned a value) and false otherwise
- isSetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
Returns true if field qualifier is set (has been assigned a value) and false otherwise
- isSetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
Returns true if field qualifier is set (has been assigned a value) and false otherwise
- isSetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
Returns true if field qualifier is set (has been assigned a value) and false otherwise
- isSetQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
Returns true if field qualifier is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRowBatches() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
Returns true if field rowBatches is set (has been assigned a value) and false otherwise
- isSetRowBatches() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Returns true if field rowBatches is set (has been assigned a value) and false otherwise
- isSetRowMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
Returns true if field rowMutations is set (has been assigned a value) and false otherwise
- isSetRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
Returns true if field rows is set (has been assigned a value) and false otherwise
- isSetRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Returns true if field rows is set (has been assigned a value) and false otherwise
- isSetRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Returns true if field rows is set (has been assigned a value) and false otherwise
- isSetRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Returns true if field rows is set (has been assigned a value) and false otherwise
- isSetScan() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Returns true if field scan is set (has been assigned a value) and false otherwise
- isSetScan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
Returns true if field scan is set (has been assigned a value) and false otherwise
- isSetScan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
Returns true if field scan is set (has been assigned a value) and false otherwise
- isSetScannerId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
Returns true if field scannerId is set (has been assigned a value) and false otherwise
- isSetScannerId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
Returns true if field scannerId is set (has been assigned a value) and false otherwise
- isSetServerName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
Returns true if field serverName is set (has been assigned a value) and false otherwise
- isSetSortColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
Returns true if field sortColumns is set (has been assigned a value) and false otherwise
- isSetSortedColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
Returns true if field sortedColumns is set (has been assigned a value) and false otherwise
- isSetStartAndPrefix() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Returns true if field startAndPrefix is set (has been assigned a value) and false otherwise
- isSetStartKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
Returns true if field startKey is set (has been assigned a value) and false otherwise
- isSetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Returns true if field startRow is set (has been assigned a value) and false otherwise
- isSetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Returns true if field startRow is set (has been assigned a value) and false otherwise
- isSetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Returns true if field startRow is set (has been assigned a value) and false otherwise
- isSetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Returns true if field startRow is set (has been assigned a value) and false otherwise
- isSetStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
Returns true if field startRow is set (has been assigned a value) and false otherwise
- isSetStartRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Returns true if field startRow is set (has been assigned a value) and false otherwise
- isSetStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Returns true if field stopRow is set (has been assigned a value) and false otherwise
- isSetStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Returns true if field stopRow is set (has been assigned a value) and false otherwise
- isSetStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
Returns true if field stopRow is set (has been assigned a value) and false otherwise
- isSetStopRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Returns true if field stopRow is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
Returns true if field tableNameOrRegionName is set (has been assigned a value) and false otherwise
- isSetTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
Returns true if field tableNameOrRegionName is set (has been assigned a value) and false otherwise
- isSetTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
Returns true if field timeRange is set (has been assigned a value) and false otherwise
- isSetTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Returns true if field timeRange is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTimeToLive() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
Returns true if field timeToLive is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetVersion() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
Returns true if field version is set (has been assigned a value) and false otherwise
- isSetWriteToWAL() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
Returns true if field writeToWAL is set (has been assigned a value) and false otherwise
- isSetWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
Returns true if field writeToWal is set (has been assigned a value) and false otherwise
- isSetWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
Returns true if field writeToWal is set (has been assigned a value) and false otherwise
- isSetWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
Returns true if field writeToWal is set (has been assigned a value) and false otherwise
- isShowConfInServlet() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
- isSingleRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- isSkipChecks() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- isSlaveDown() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Check if the slave is down by trying to establish a connection
- isSmall() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether this scan is a small scan
- isSnapshotCorrupted() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- isSnapshotDone(HSnapshotDescription) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
- isSnapshotDone(HSnapshotDescription) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Checks if the specified snapshot is done.
- isSnapshotDone(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Check if the specified snapshot is done
- isSnapshotFinished(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Check the current state of the passed snapshot.
- isSortColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- isSplit() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isSplit() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- isSplit() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- isSplitParent() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isSplitParent() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- isSplittable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isSplitting() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isStopped() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- isStopped() - Method in interface org.apache.hadoop.hbase.Stoppable
-
- isStopping() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isStopping() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- isSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- isSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- isSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- isSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- issueDate - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- 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(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isTableEnabled(ByteBuffer) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- isTableEnabled(ByteBuffer, Callback<Boolean>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- isTableEnabled(ByteBuffer) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- isTableEnabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
A table that isTableEnabled == false and isTableDisabled == false
is possible.
- 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(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
-
Tells whether or not a table is enabled or not.
- isTableEnabled(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.isTableEnabled_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- isTableEnabled(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.isTableEnabled_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- isTableEnabled(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- isTableEnabled(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
- isTableEnabled(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- isTableInfoExists(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Checks if .tableinfo exists for given table
- isTablePresent(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
check if table is present .
- isTaskPath(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- isThisOurZnode(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Checks if the provided znode is the same as this region server's
- isTop() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- isTopFileRegion(Reference.Range) - Static method in class org.apache.hadoop.hbase.io.Reference
-
- istream - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Stream to read from.
- istreamNoFsChecksum - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
The file system stream of the underlying
HFile
that
does not do checksum verification in the file system
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.PlainTextMessageBodyProducer
-
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.ProtobufMessageBodyProducer
-
- isWriteToWAL() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- isWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- isWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- isWriteToWal() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- isWriting() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- 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() - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
- iterator() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- iterator() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- iterator() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- iterator() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
- iterator() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- 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
-
- randomAssignment(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.DefaultLoadBalancer
-
- randomAssignment(List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Get a random region server from the list
- RandomRowFilter - Class in org.apache.hadoop.hbase.filter
-
A filter that includes rows based on a chance.
- RandomRowFilter() - Constructor for class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Writable constructor, do not use.
- 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
-
Return the array of KeyValues backing this Result instance.
- REACHED_BARRIER_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- reachedZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- read(DataInputStream) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- read(ByteBuffer) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- read(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.Reference
-
Read a Reference from FileSystem.
- read() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection.PingInputStream
-
Read a byte from the stream.
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection.PingInputStream
-
Read bytes into a buffer starting from offset off
Send a ping if timeout on read.
- read() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- read(byte[]) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- read(byte[], int, int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- read(DataInput) - Static method in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.AuthMethod
-
Read from in
- read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- read(TProtocol) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- read(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- 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
-
- readAllEntriesToReplicateOrNextFile(boolean, List<HLog.Entry>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Read all the entries from the current log files and retain those
that need to be replicated.
- readAndCheck(DataInputStream) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
Reads a magic record of the length
BlockType.MAGIC_LENGTH
from the given
stream and expects it to match this block type.
- readAndCheck(ByteBuffer) - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
Reads a magic record of the length
BlockType.MAGIC_LENGTH
from the given
byte buffer and expects it to match this block type.
- readAndProcess() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- readAndProcess() - Method in class org.apache.hadoop.hbase.ipc.SecureServer.SecureConnection
-
- readArray(DataInput) - Static method in class org.apache.hadoop.hbase.client.Result
-
- readAttributes(DataInput) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- readBlock(long, long, boolean, boolean, boolean, BlockType) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader
-
- readBlock(long, long, boolean, boolean, boolean, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1
-
- readBlock(long, long, boolean, boolean, boolean, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
Read in a file block.
- readBlockData(long, long, int, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
Reads the block at the given offset in the file with the given on-disk
size and uncompressed size.
- 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.
- readClusterIdZNode(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ClusterId
-
- 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.
- reader - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- reader - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.AbstractScannerV1
-
This masks a field with the same name in the superclass and saves us the
runtime overhead of casting from abstract reader to reader V1.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Action
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Append
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.coprocessor.Exec
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.coprocessor.ExecResult
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Delete
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Get
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Increment
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.MultiPut
-
Deprecated.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.MultiPutResponse
-
Deprecated.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Put
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Result
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.client.Scan
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.executor.RegionTransitionData
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.filter.WritableByteArrayComparable
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HServerAddress
-
Deprecated.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HServerLoad
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL This method is a part of WritableComparable
interface
and is used for de-serialization of the HTableDescriptor over RPC
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.Reference
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.ipc.Invocation
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.ipc.ProtocolSignature
-
- readFields(int, DataInput) - Method in class org.apache.hadoop.hbase.KeyValue
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.KeyValue
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Reads the values of each field.
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- readFields(DataInput) - Method in class org.apache.hadoop.hbase.snapshot.HSnapshotDescription
-
INTERNAL This method is a part of Writable
interface
and is used for de-serialization of the HTableDescriptor over RPC
- readFilter(DataInput, Configuration) - Static method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
Read a
Filter
which is written as a
Writable
or a
Filter
directly.
- readFrom(Class<ProtobufMessageHandler>, Type, Annotation[], MediaType, MultivaluedMap<String, String>, InputStream) - Method in class org.apache.hadoop.hbase.rest.provider.consumer.ProtobufMessageBodyConsumer
-
- readFromStream(FSDataInputStream, long) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Reads a file trailer from the given file.
- 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.
- readMetaLocation(HRegionInterface) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Deprecated.
Does not retry; use #getMetaRegionLocation(CatalogTracker)
- readMultiLevelIndexRoot(HFileBlock, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Read the root-level metadata of a multi-level block index.
- readNextAndSetPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
-
Get the next entry, returned and also added in the array
- readNextDataBlock() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
Scans blocks in the "scanned" section of the
HFile
until the next
data block is found.
- readObject(DataInput, Configuration) - Static method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
Read a
Writable
,
String
, primitive type, or an array of
the preceding.
- readObject(DataInput, HbaseObjectWritable, Configuration) - Static method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
Read a
Writable
,
String
, primitive type, or an array of
the preceding.
- readOnly - Variable in class org.apache.hadoop.hbase.avro.generated.ATableDescriptor
-
- 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
- READONLY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- readPermissions(DataInput, Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Reads a set of permissions as Writable
instances
from the input stream.
- readRawVarint32(DataInput) - Static method in class org.apache.hadoop.hbase.util.ProtoUtil
-
Read a variable length integer in the same format that ProtoBufs encodes.
- readRequestsCount - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
Count of read requests
- READREQUESTSCOUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- readRootIndex(DataInput, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Read in the root-level index from the given input stream.
- readRootIndex(HFileBlock, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Read in the root-level index from the given input stream.
- readSnapshotInfo(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- 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.
- readTimestamp(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffCompressionState
-
- 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.
- readWithExtra(InputStream, byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Read from an input stream.
- realSeekDone() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
We optimize our store scanners by checking the most recent store file
first, so we sometimes pretend we have done a seek but delay it until the
store scanner bubbles up to the top of the key-value heap.
- realSeekDone() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- realSeekDone() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- rebuildMeta(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Rebuilds meta from information in hdfs/fs.
- receive(ForeignException) - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- receive(ForeignException) - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionListener
-
Receive a ForeignException.
- receive(ForeignException) - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
A callback that handles incoming ForeignExceptions.
- receiveAbortProcedure(String, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Send abort to the specified procedure
- receivedBytes - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
The metrics variables are public:
- they can be set directly by calling their set/inc methods
-they can also be read directly - e.g.
- receivedReachedGlobalBarrier(String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Notification that procedure coordinator has reached the global barrier
- receiveReachedGlobalBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Callback for the member rpcs to call when the global barrier has been reached.
- receiveResponse() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- receiveResponse() - Method in class org.apache.hadoop.hbase.ipc.SecureClient.SecureConnection
-
- reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- reconnectAfterExpiration() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- RecoverableZooKeeper - Class in org.apache.hadoop.hbase.zookeeper
-
A zookeeper that can handle 'recoverable' errors.
- RecoverableZooKeeper(String, int, Watcher, int, int) - Constructor for class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- RECOVERED_EDITS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
Name of file that holds recovered edits written by the wal log splitting
code, one per region
- RECOVERED_EDITS_DIR - Static variable in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- RECOVERED_LOG_TMPFILE_SUFFIX - Static variable in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- recoveredEdits(String, String) - Method in interface org.apache.hadoop.hbase.util.FSVisitor.RecoveredEditsVisitor
-
- recoverFileLease(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.util.FSHDFSUtils
-
Recover the lease from HDFS, retrying multiple times.
- recoverFileLease(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.util.FSMapRUtils
-
- recoverFileLease(FileSystem, Path, Configuration) - Method in class org.apache.hadoop.hbase.util.FSUtils
-
Recover file lease.
- recoverTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- recv_atomicIncrement() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_checkAndDelete() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_checkAndPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_closeScanner() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_compact() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_createTable() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_deleteAll() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_deleteAllRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_deleteAllRowTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_deleteAllTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_deleteMultiple() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_deleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_deleteTable() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_disableTable() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_enableTable() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_exists() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_get() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_get() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_getColumnDescriptors() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getMultiple() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_getRegionInfo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getRowOrBefore() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getRowsTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getRowsWithColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getRowsWithColumnsTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getRowTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getRowWithColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getRowWithColumnsTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getScannerResults() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_getScannerRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_getTableNames() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getTableRegions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getVer() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_getVerTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_increment() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_increment() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_incrementRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_isTableEnabled() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_majorCompact() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_mutateRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_mutateRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_mutateRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_mutateRowsTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_mutateRowTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_openScanner() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_put() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_putMultiple() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- recv_scannerClose() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_scannerGet() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_scannerGetList() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_scannerOpen() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_scannerOpenTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_scannerOpenWithPrefix() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_scannerOpenWithScan() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_scannerOpenWithStop() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- recv_scannerOpenWithStopTs() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- 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<Writable>, Reducer<Writable, Writable, Writable, Writable>.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(ImmutableBytesWritable, Iterable<Put>, Reducer<ImmutableBytesWritable, Put, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.PutSortReducer
-
- REENTRANT_LOCK - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ReentrantReadWriteLock
- Reference - Class in org.apache.hadoop.hbase.io
-
A reference to the top or bottom half of a store file.
- Reference(byte[], Reference.Range) - Constructor for class org.apache.hadoop.hbase.io.Reference
-
Constructor
- Reference() - Constructor for class org.apache.hadoop.hbase.io.Reference
-
Used by serializations.
- REFERENCE - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Reference size is 8 bytes on 64-bit, 4 bytes on 32-bit
- Reference.Range - Enum in org.apache.hadoop.hbase.io
-
For split HStoreFiles, it specifies if the file covers the lower half or
the upper half of the key range
- ReferenceRegionHFilesTask - Class in org.apache.hadoop.hbase.snapshot
-
Reference all the hfiles in a region for a snapshot.
- ReferenceRegionHFilesTask(HBaseProtos.SnapshotDescription, ForeignExceptionDispatcher, Path, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.snapshot.ReferenceRegionHFilesTask
-
Reference all the files in the given region directory
- ReferenceServerWALsTask - Class in org.apache.hadoop.hbase.snapshot
-
Reference all the WAL files under a server's WAL directory
- ReferenceServerWALsTask(HBaseProtos.SnapshotDescription, ForeignExceptionDispatcher, Path, Configuration, FileSystem) - Constructor for class org.apache.hadoop.hbase.snapshot.ReferenceServerWALsTask
-
- refreshAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceMetrics
-
Convenience method to use the last given timestamp to refresh the age
of the last edit.
- refreshCacheFromWritable(byte[], byte[]) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- RegexStringComparator - Class in org.apache.hadoop.hbase.filter
-
- RegexStringComparator() - Constructor for class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Nullary constructor for Writable, do not use
- RegexStringComparator(String) - 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 - Variable in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
The region configured for this split policy.
- REGION_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- REGION_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REGION_PREFIX - Static variable in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- REGION_SERVER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for what region server interface to use.
- 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_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_TEMP_SUBDIR - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Temporary subdirectory of the region directory used for compaction output.
- 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
-
- RegionCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
-
- RegionCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver
-
Implements the coprocessor environment and runtime support for coprocessors
loaded within a
HRegion
.
- RegionCoprocessorHost(HRegion, RegionServerServices, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
Constructor
- regionDirPattern - Static variable in class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
-
- 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_FILE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Name of the region info file that resides just under the region directory.
- REGIONINFO_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The regioninfo column qualifier
- RegionMetricsStorage - Class in org.apache.hadoop.hbase.regionserver.metrics
-
This class if for maintaining the maps used to power metrics for hfiles,
regions, and regionservers.
- RegionMetricsStorage() - Constructor for class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
- RegionObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
Coprocessors implement this interface to observe and mediate client actions
on the region.
- regionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Marks the region as offline.
- 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
-
- RegionOpeningState - Enum in org.apache.hadoop.hbase.regionserver
-
- RegionPlan - Class in org.apache.hadoop.hbase.master
-
Stores the plan for the move of an individual region.
- RegionPlan(HRegionInfo, ServerName, ServerName) - Constructor for class org.apache.hadoop.hbase.master.RegionPlan
-
Instantiate a plan for a region move, moving the specified region from
the specified source server to the specified destination server.
- regions - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
Count of regions carried by this regionserver
- REGIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- REGIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- REGIONS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- RegionScanner - Interface in org.apache.hadoop.hbase.regionserver
-
RegionScanner describes iterators over rows in an HRegion.
- regionsCount - Variable in class org.apache.hadoop.hbase.avro.generated.AClusterStatus
-
- REGIONSERVER - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
region server process name
- REGIONSERVER_CONF - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
region server configuration name
- REGIONSERVER_COPROCESSOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- REGIONSERVER_INFO_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for port region server's info server listens on.
- REGIONSERVER_INFO_PORT_AUTO - Static variable in class org.apache.hadoop.hbase.HConstants
-
A flag that enables automatic selection of regionserver info port
- regionserver_jsp - Class in org.apache.hadoop.hbase.generated.regionserver
-
- regionserver_jsp() - Constructor for class org.apache.hadoop.hbase.generated.regionserver.regionserver_jsp
-
- REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for port region server listens on.
- RegionServerAccounting - Class in org.apache.hadoop.hbase.regionserver
-
RegionServerAccounting keeps record of some basic real time information about
the Region Server.
- RegionServerAccounting() - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- RegionServerCoprocessorEnvironment - Interface in org.apache.hadoop.hbase.coprocessor
-
- RegionServerCoprocessorHost - Class in org.apache.hadoop.hbase.regionserver
-
- RegionServerCoprocessorHost(RegionServerServices, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- RegionServerDynamicMetrics - Class in org.apache.hadoop.hbase.regionserver.metrics
-
This class is for maintaining the various RPC statistics
and publishing them through the metrics interfaces.
- RegionServerDynamicStatistics - Class in org.apache.hadoop.hbase.regionserver.metrics
-
- RegionServerDynamicStatistics(MetricsRegistry) - Constructor for class org.apache.hadoop.hbase.regionserver.metrics.RegionServerDynamicStatistics
-
- RegionServerMetrics - Class in org.apache.hadoop.hbase.regionserver.metrics
-
This class is for maintaining the various regionserver statistics
and publishing them through the metrics interfaces.
- RegionServerMetrics() - Constructor for class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- RegionServerObserver - Interface in org.apache.hadoop.hbase.coprocessor
-
- regionServerReport(byte[], HServerLoad) - Method in interface org.apache.hadoop.hbase.ipc.HMasterRegionInterface
-
- regionServerReport(byte[], HServerLoad) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- 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
- RegionServerServices - Interface in org.apache.hadoop.hbase.regionserver
-
- RegionServerSnapshotManager - Class in org.apache.hadoop.hbase.regionserver.snapshot
-
This manager class handles the work dealing with snapshots for a
HRegionServer
.
- RegionServerSnapshotManager(RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Create a default snapshot handler - uses a zookeeper based member controller.
- RegionServerSnapshotManager.SnapshotSubprocedureBuilder - Class in org.apache.hadoop.hbase.regionserver.snapshot
-
Build the actual snapshot runner that will do all the 'hard' work
- RegionServerSnapshotManager.SnapshotSubprocedureBuilder() - Constructor for class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedureBuilder
-
- regionServerStartup(int, long, long) - Method in interface org.apache.hadoop.hbase.ipc.HMasterRegionInterface
-
Called when a region server first starts.
- regionServerStartup(int, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- RegionServerStatistics - Class in org.apache.hadoop.hbase.regionserver.metrics
-
- RegionServerStatistics(MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.regionserver.metrics.RegionServerStatistics
-
- 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
-
- RegionServerTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracks the online region servers via ZK.
- RegionServerTracker(ZooKeeperWatcher, Abortable, ServerManager) - Constructor for class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
-
- regionsLoad - Variable in class org.apache.hadoop.hbase.avro.generated.AServerLoad
-
- RegionSplitCalculator<R extends KeyRange> - Class in org.apache.hadoop.hbase.util
-
This is a generic region split calculator.
- RegionSplitCalculator(Comparator<R>) - Constructor for class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
- regionSplitFailureCount - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- RegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A split policy determines when a region should be split.
- RegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- regionSplitSuccessCount - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- RegionSplitter - Class in org.apache.hadoop.hbase.util
-
The
RegionSplitter
class provides several utilities to help in the
administration lifecycle for developers who choose to manually split regions
instead of having HBase handle that automatically.
- RegionSplitter() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter
-
- RegionSplitter.HexStringSplit - Class in org.apache.hadoop.hbase.util
-
- RegionSplitter.HexStringSplit() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- RegionSplitter.SplitAlgorithm - Interface in org.apache.hadoop.hbase.util
-
A generic interface for the RegionSplitter code to use for all it's
functionality.
- RegionSplitter.UniformSplit - Class in org.apache.hadoop.hbase.util
-
A SplitAlgorithm that divides the space of possible keys evenly.
- RegionSplitter.UniformSplit() - Constructor for class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- RegionsResource - Class in org.apache.hadoop.hbase.rest
-
- RegionsResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.RegionsResource
-
Constructor
- 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
- RegionTransitionData - Class in org.apache.hadoop.hbase.executor
-
Data serialized into ZooKeeper for region transitions.
- RegionTransitionData() - Constructor for class org.apache.hadoop.hbase.executor.RegionTransitionData
-
Writable constructor.
- RegionTransitionData(EventHandler.EventType, byte[]) - Constructor for class org.apache.hadoop.hbase.executor.RegionTransitionData
-
Construct data for a new region transition event with the specified event
type and region name.
- RegionTransitionData(EventHandler.EventType, byte[], ServerName) - Constructor for class org.apache.hadoop.hbase.executor.RegionTransitionData
-
Construct data for a new region transition event with the specified event
type, region name, and server name.
- RegionTransitionData(EventHandler.EventType, byte[], ServerName, byte[]) - Constructor for class org.apache.hadoop.hbase.executor.RegionTransitionData
-
Construct data for a new region transition event with the specified event
type, region name, and server name.
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos
-
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos
-
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage
-
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage
-
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage
-
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage
-
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage
-
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage
-
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage
-
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage
-
- registerAllExtensions(ExtensionRegistry) - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage
-
- registerFilter(String, String) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Register a new filter with the parser.
- registerFilters(Configuration) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
-
- registerFilters(Configuration) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftServer
-
Adds the option to pre-load filters at startup.
- registerListener(EventHandler.EventType, EventHandler.EventHandlerListener) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- registerListener(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Register the specified listener to receive ZooKeeper events.
- registerListenerFirst(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Register the specified listener to receive ZooKeeper events and add it as
the first in the list of current listeners.
- registerProtocol(Class<T>, T) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- registerProtocol(Class<T>, T) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- registerProtocol(Class<T>, T) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Registers a new CoprocessorProtocol subclass and instance to
be available for handling
HRegion.exec(Exec)
calls.
- registerRegionServerListener(ZooKeeperListener) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
- registerWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- registry - Variable in class org.apache.hadoop.hbase.metrics.HBaseInfo
-
- registry - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
-
- registry - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerDynamicMetrics
-
The metrics variables are public:
- they can be set directly by calling their set/inc methods
-they can also be read directly - e.g.
- registryLength - Variable in class org.apache.hadoop.hbase.metrics.MetricsMBeanBase
-
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest.Rejection
-
- releaseBarrier() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
Hooray!
- releaseCompressor() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Releases the compressor this writer uses to compress blocks into the
compressor pool.
- releaseHTableInterface(HTableInterface) - Method in class org.apache.hadoop.hbase.client.HTableFactory
-
- releaseHTableInterface(HTableInterface) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
-
Release the HTable resource represented by the table.
- releaseLockEntry(IdLock.Entry) - Method in class org.apache.hadoop.hbase.util.IdLock
-
Must be called in a finally block to decrease the internal counter and
remove the monitor object for the given id if the caller is the last
client.
- releaseRowLock(Integer) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Release the row lock!
- reloadZkWatcher() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
-
Closes the current ZKW (if not null) and creates a new one
- relocateRegion(byte[], 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.
- remainingCapacity() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- 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
- RemoteExceptionHandler - Class in org.apache.hadoop.hbase
-
An immutable class which contains a static method for handling
org.apache.hadoop.ipc.RemoteException exceptions.
- 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, String, String) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
Deprecated.
accessToken is not used and will be removed
- RemoteHTable(Client, Configuration, String) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
Constructor
- RemoteHTable(Client, Configuration, String, String) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
Deprecated.
accessToken is not used and will be removed
- RemoteHTable(Client, Configuration, byte[]) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
Constructor
- RemoteHTable(Client, Configuration, byte[], String) - Constructor for class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
Deprecated.
accessToken is not used and will be removed
- remoteId - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- remotePort - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- remove(HTableDescriptor) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Remove all
Constraints
that have been added to the table
and turn off the constraint processing.
- remove(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Remove the constraint (and associated information) for the table
descriptor.
- remove(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- remove(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- remove(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- remove(Object) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- remove(Object) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- remove(Object) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- remove(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Deletes the mapping for the specified key if it exists.
- 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.rest.RowResultGenerator
-
- remove() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- remove(byte[]) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- remove(String) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
- remove() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- remove(Object) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- remove(String) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- remove(R) - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- remove(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- remove(K, V) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- remove(Object) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- remove(Object) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- removeAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- removeAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- removeAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- removeClosedRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
When a region is closed, it should be removed from the regionsToReopen
- removeColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- removeCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Remove a coprocessor from those set on the table
- removeDeadNotExpiredServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Loop through the deadNotExpired server list and remove them from the
servers.
- removeEnablingTable(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
If the table is found in ENABLING state the inmemory state is removed.
- 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
- removeFromOnlineRegions(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- removeFromRegionsInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- removeFromRegionsInTransition(HRegionInfo) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Remove passed hri
from the internal list of regions in transition on this
regionserver.
- removeKeyFromZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- removeLiveNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- removeLogFromList(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Remove a log from the list of hlogs in zookeeper
- removeMetaData(byte[]) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- removeNonReplicableEdits(WALEdit) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
We only want KVs that are scoped other than local
- removePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Removes a peer cluster and stops the replication to it.
- removePeer(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Thie method first deletes all the recovered sources for the specified
id, then deletes the normal source (deleting all related data in ZK).
- removePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Remove the peer from zookeeper.
- 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
- removeRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- removeRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- removeRows(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- removeScanner(int) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
Removes the scanner associated with the specified ID from the internal
id->scanner hash-map.
- removeScanner(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Removes the scanner associated with the specified ID from the internal
id->scanner hash-map.
- removeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
Removes the scanner associated with the specified ID from the internal HashMap.
- removeServerFromDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- removeShutdownHook(Runnable) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- removeTrace(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- removeValues(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- rename(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Utility to help with rename.
- renameAndSetModifyTime(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hbase.HBaseFileSystem
-
rename the src path to dest path and set the dest path's modify time to current timestamp
- renameDirForFileSystem(FileSystem, Path, Path) - Static method in class org.apache.hadoop.hbase.HBaseFileSystem
-
Renames a directory.
- render(Writer) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- render(Writer, AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- render(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- render(Writer, HMaster, HBaseAdmin) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- render(Writer, HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.Intf
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.Intf
-
- renderNoFlush(Writer, AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl.Intf
-
- renderNoFlush(Writer, HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.Intf
-
- renderNoFlush(Writer, HMaster, HBaseAdmin) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmplImpl
-
- renderNoFlush(Writer) - Method in interface org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.Intf
-
- renderNoFlush(Writer, HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- renderNoFlush(Writer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmplImpl
-
- renewLease(String) - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Renew a lease
- reOpenAllRegions(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- replaceValue(V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Replace the value of this entry.
- replayRecoveredEditsIfAny(Path, Map<byte[], Long>, CancelableProgressable, MonitoredTask) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Read the edits log put under this region by wal log splitting process.
- replicateEntries(HLog.Entry[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Replicate this array of entries directly into the local cluster
using the native client.
- replicateLogEntries(HLog.Entry[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Replicates the given entries.
- replicateLogEntries(HLog.Entry[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- replicateLogEntries(HLog.Entry[]) - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSinkService
-
Carry on the list of log entries down to the sink
- replicateLogEntries(HLog.Entry[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Carry on the list of log entries down to the sink
- Replication - Class in org.apache.hadoop.hbase.replication.regionserver
-
Gateway to Replication.
- Replication(Server, FileSystem, Path, Path) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Instantiate the replication management (if rep is enabled).
- Replication() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Empty constructor
- REPLICATION_ENABLE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_LOG_DIR - Static variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
- REPLICATION_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- REPLICATION_SCOPE - 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.
- replicationCallQueueLen - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- REPLICATIONGLOBAL - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- ReplicationHLogReaderManager - Class in org.apache.hadoop.hbase.replication.regionserver
-
Wrapper class around HLog to help manage the implementation details
such as compression.
- ReplicationHLogReaderManager(FileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
-
Creates the helper but doesn't open any file
Use setInitialPosition after using the constructor if some content needs to be skipped
- ReplicationLogCleaner - Class in org.apache.hadoop.hbase.replication.master
-
Implementation of a log cleaner that checks if a log is still scheduled for
replication before deleting it when its TTL is over.
- ReplicationLogCleaner() - Constructor for class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
Instantiates the cleaner, does nothing more.
- ReplicationPeer - Class in org.apache.hadoop.hbase.replication
-
This class acts as a wrapper for all the objects used to identify and
communicate with remote peers and is responsible for answering to expired
sessions and re-establishing the ZK connections.
- ReplicationPeer(Configuration, String, String) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeer
-
Constructor that takes all the objects required to communicate with the
specified peer, except for the region server addresses.
- ReplicationPeer.PeerStateTracker - Class in org.apache.hadoop.hbase.replication
-
Tracker for state of this peer
- ReplicationPeer.PeerStateTracker(String, ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationPeer.PeerStateTracker
-
- replicationQueue - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
replication related queue;
- ReplicationService - Interface in org.apache.hadoop.hbase.regionserver
-
Gateway to Cluster Replication.
- ReplicationSink - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is responsible for replicating the edits coming
from another cluster.
- ReplicationSink(Configuration, Stoppable) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Create a sink for replication
- ReplicationSinkMetrics - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is for maintaining the various replication statistics
for a sink and publishing them through the metrics interfaces.
- ReplicationSinkMetrics() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkMetrics
-
Constructor used to register the metrics
- ReplicationSinkService - Interface in org.apache.hadoop.hbase.regionserver
-
A sink for a replication stream has to expose this service.
- ReplicationSource - Class in org.apache.hadoop.hbase.replication.regionserver
-
Class that handles the source of a replication stream.
- ReplicationSource() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- ReplicationSource.LogsComparator - Class in org.apache.hadoop.hbase.replication.regionserver
-
Comparator used to compare logs together based on their start time
- ReplicationSource.LogsComparator() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.LogsComparator
-
- ReplicationSourceInterface - Interface in org.apache.hadoop.hbase.replication.regionserver
-
Interface that defines a replication source
- ReplicationSourceManager - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is responsible to manage all the replication
sources.
- ReplicationSourceManager(ReplicationZookeeper, Configuration, Stoppable, FileSystem, AtomicBoolean, Path, Path) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Creates a replication manager and sets the watch on all the other
registered region servers
- ReplicationSourceManager.OtherRegionServerWatcher - Class in org.apache.hadoop.hbase.replication.regionserver
-
Watcher used to be notified of the other region server's death
in the local cluster.
- ReplicationSourceManager.OtherRegionServerWatcher(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager.OtherRegionServerWatcher
-
Construct a ZooKeeper event listener.
- ReplicationSourceManager.PeersWatcher - Class in org.apache.hadoop.hbase.replication.regionserver
-
Watcher used to follow the creation and deletion of peer clusters.
- ReplicationSourceManager.PeersWatcher(ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager.PeersWatcher
-
Construct a ZooKeeper event listener.
- ReplicationSourceMetrics - Class in org.apache.hadoop.hbase.replication.regionserver
-
This class is for maintaining the various replication statistics
for a source and publishing them through the metrics interfaces.
- ReplicationSourceMetrics(String) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceMetrics
-
Constructor used to register the metrics
- ReplicationSourceService - Interface in org.apache.hadoop.hbase.regionserver
-
A source for a replication stream has to expose this service.
- ReplicationStatistics - Class in org.apache.hadoop.hbase.replication.regionserver
-
- ReplicationStatistics(MetricsRegistry, String) - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatistics
-
Constructor to register the MBean
- ReplicationSyncUp - Class in org.apache.hadoop.hbase.replication.regionserver
-
In a scenario of Replication based Disaster/Recovery, when hbase
Master-Cluster crashes, this tool is used to sync-up the delta from Master to
Slave using the info from Zookeeper.
- ReplicationSyncUp() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
- REPLICATIONTYPE - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- ReplicationZookeeper - Class in org.apache.hadoop.hbase.replication
-
This class serves as a helper for all things related to zookeeper in
replication.
- ReplicationZookeeper(Abortable, Configuration, ZooKeeperWatcher) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Constructor used by clients of replication (like master and HBase clients)
- ReplicationZookeeper(Server, AtomicBoolean) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Constructor used by region servers, connects to the peer cluster right away.
- ReplicationZookeeper.PeerState - Enum in org.apache.hadoop.hbase.replication
-
- ReplicationZookeeper.ReplicationStatusTracker - Class in org.apache.hadoop.hbase.replication
-
Tracker for status of the replication
- ReplicationZookeeper.ReplicationStatusTracker(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationZookeeper.ReplicationStatusTracker
-
- report(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- report(HBaseFsck.ErrorReporter) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Print a human readable summary of hfile quarantining operations.
- reportError(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- reportError(HBaseFsck.ErrorReporter.ERROR_CODE, String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- reportError(HBaseFsck.ErrorReporter.ERROR_CODE, String, HBaseFsck.TableInfo) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- reportError(HBaseFsck.ErrorReporter.ERROR_CODE, String, HBaseFsck.TableInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- reportError(HBaseFsck.ErrorReporter.ERROR_CODE, String, HBaseFsck.TableInfo, HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- reportRSFatalError(byte[], String) - Method in interface org.apache.hadoop.hbase.ipc.HMasterRegionInterface
-
Called by a region server to report a fatal error that is causing
it to abort.
- reportRSFatalError(byte[], String) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- request - Variable in class org.apache.hadoop.hbase.client.MultiPutResponse
-
Deprecated.
- requestCompaction(HRegion, String) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
-
- requestCompaction(HRegion, String, List<CompactionRequest>) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
-
- requestCompaction(HRegion, Store, String, CompactionRequest) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
-
- requestCompaction(HRegion, String, int, List<CompactionRequest>) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
-
- requestCompaction(HRegion, Store, String, int, CompactionRequest) - Method in interface org.apache.hadoop.hbase.regionserver.CompactionRequestor
-
- requestCompaction(HRegion, String) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestCompaction(HRegion, String, List<CompactionRequest>) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestCompaction(HRegion, Store, String, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestCompaction(HRegion, String, int, List<CompactionRequest>) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestCompaction(HRegion, Store, String, int, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestCompaction() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- requestCompaction(int, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- RequestContext - Class in org.apache.hadoop.hbase.ipc
-
Represents client information (authenticated username, remote address, protocol)
for the currently executing request within a RPC server handler thread.
- requestDelayedFlush(HRegion, long) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Tell the listener the cache needs to be flushed after a delay
- requestFlush(HRegion) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Tell the listener the cache needs to be flushed.
- requests - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- REQUESTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- REQUESTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- requestsCount - Variable in class org.apache.hadoop.hbase.avro.generated.AClusterStatus
-
- requestSeek(KeyValue, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- requestSeek(KeyValue, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
- requestSeek(KeyValue, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- requestSeek(KeyValue, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Pretend we have done a seek but don't do it yet, if possible.
- requestSplit(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requestSplit(HRegion, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- requirePermission(String, Permission.Action, RegionCoprocessorEnvironment, Map<byte[], ? extends Collection<?>>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Authorizes that the current user has permission to perform the given
action on the set of table column families.
- reseek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
This function is identical to the
KeyValueHeap.seek(KeyValue)
function except
that scanner.seek(seekKey) is changed to scanner.reseek(seekKey).
- reseek(KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Reseek the scanner at or after the specified KeyValue.
- reseek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
-
Move forward on the sub-lists set previously by seek.
- reseek(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
Do a reseek to the required row.
- reseek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- reseek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- reseek(KeyValue) - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- reseekTo(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- reseekTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.AbstractScannerV1
-
- reseekTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- reseekTo(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Reseek to or just before the passed key
.
- reseekTo(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- 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 interface org.apache.hadoop.hbase.filter.Filter
-
Reset the state of the filter between rows.
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that are purely stateless and do nothing in their reset() methods can inherit
this null/empty implementation.
- reset() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- reset() - Method in class org.apache.hadoop.hbase.filter.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 - Variable in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
-
- reset() - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Resets the Matcher
- reset() - Static method in class org.apache.hadoop.hbase.regionserver.DebugPrint
-
- reset() - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
-
Called between rows.
- reset() - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
- reset() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Reader
-
- reset() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- reset() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- reset() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
- resetAllMinMax() - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
-
- resetAllMinMax() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- resetAllMinMax() - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- resetBuffer() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- resetBuffer() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- resetCounters() - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- resetErrors() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- resetMembers(Procedure) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify Members to reset the distributed state for procedure
- resetMembers(Procedure) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
Delete znodes that are no longer in use.
- resetMetaLocation() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Called when we figure current meta is off (called from zk callback).
- resetMinMaxAvg() - Method in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
-
Rollover to a new interval
NOTE: does not reset numOps.
- resetRpcTimeout() - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
-
- resetSchemaMetricsConf(SchemaConfigured) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
Reset schema metrics configuration in this particular instance.
- resetState() - Method in class org.apache.hadoop.hbase.io.hfile.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
- resetThreadReadPoint(MultiVersionConsistencyControl) - Static method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Set the thread MVCC read point to whatever the current read point is in
this particular instance of MVCC.
- resetThreadReadPoint() - Static method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Set the thread MVCC read point to 0 (include everything).
- ResourceBase - Class in org.apache.hadoop.hbase.rest
-
- ResourceBase() - Constructor for class org.apache.hadoop.hbase.rest.ResourceBase
-
- ResourceConfig - Class in org.apache.hadoop.hbase.rest
-
- ResourceConfig() - Constructor for class org.apache.hadoop.hbase.rest.ResourceConfig
-
- responder - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- responder - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- response - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- 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
- responseQueue - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- responseQueue - Variable in class org.apache.hadoop.hbase.ipc.SecureServer.SecureConnection
-
- rest_jsp - Class in org.apache.hadoop.hbase.generated.rest
-
- rest_jsp() - Constructor for class org.apache.hadoop.hbase.generated.rest.rest_jsp
-
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
Restart from survivable exceptions by creating a new scanner.
- restart(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
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.
- RESTMetrics - Class in org.apache.hadoop.hbase.rest.metrics
-
- RESTMetrics() - Constructor for class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- restoreEdit(Store, KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Used by tests
- restoreHdfsRegions() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Restore the on-disk table to a specified snapshot state.
- 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(HSnapshotDescription) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
- restoreSnapshot(HSnapshotDescription) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Execute Restore/Clone snapshot operation.
- restoreSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Restore the specified snapshot
- 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
-
- RestoreSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
-
Handler to Restore a snapshot.
- RestoreSnapshotHandler(MasterServices, HBaseProtos.SnapshotDescription, HTableDescriptor, MasterMetrics) - Constructor for class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- RestoreSnapshotHelper - Class in org.apache.hadoop.hbase.snapshot
-
Helper to Restore/Clone a Snapshot
- RestoreSnapshotHelper(Configuration, FileSystem, HBaseProtos.SnapshotDescription, Path, HTableDescriptor, Path, ForeignExceptionDispatcher, MonitoredTask) - Constructor for class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
- RestoreSnapshotHelper.RestoreMetaChanges - Class in org.apache.hadoop.hbase.snapshot
-
Describe the set of operations needed to update META after restore.
- RESTServlet - Class in org.apache.hadoop.hbase.rest
-
Singleton class encapsulating global REST servlet state and functions.
- RESTStatistics - Class in org.apache.hadoop.hbase.rest.metrics
-
- RESTStatistics(MetricsRegistry) - Constructor for class org.apache.hadoop.hbase.rest.metrics.RESTStatistics
-
- RESTVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- 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
-
Constructor used for Writable.
- Result(KeyValue[]) - Constructor for class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified array of KeyValues.
- Result(List<KeyValue>) - Constructor for class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified List of KeyValues.
- Result(ImmutableBytesWritable) - Constructor for class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result from the specified raw binary format.
- resultFromHBase(Result) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- ResultGenerator - Class in org.apache.hadoop.hbase.rest
-
- ResultGenerator() - Constructor for class org.apache.hadoop.hbase.rest.ResultGenerator
-
- ResultScanner - Interface in org.apache.hadoop.hbase.client
-
Interface for client-side scanning.
- resultsFromHBase(Result[]) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Converts multiple
Result
s (HBase) into a list of
TResult
s (Thrift).
- resultsToAResults(Result[]) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- resultToAResult(Result) - Static method in class org.apache.hadoop.hbase.avro.AvroUtil
-
- resume(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- resumeEncoding() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
-
Resumes encoding of the stream.
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- retainAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- retainAssignment(Map<HRegionInfo, ServerName>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.DefaultLoadBalancer
-
Generates a bulk assignment startup plan, attempting to reuse the existing
assignment information from META, but adjusting for the specified list of
available/online servers available for assignment.
- retainAssignment(Map<HRegionInfo, ServerName>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Assign regions to the previously hosting region server
- rethrowException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- rethrowException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
-
- rethrowException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- rethrowException() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTask
-
- rethrowExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- rethrowExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- rethrowExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- rethrowExceptionIfFailed() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
- retransitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Retransitions an existing unassigned node for the specified region which is
currently in the OPENING state to be in the OPENING state.
- RetriesExhaustedException - Exception in org.apache.hadoop.hbase.client
-
Exception thrown by HTable methods when an attempt to do something (like
commit changes) fails after a bunch of retries.
- RetriesExhaustedException(String) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
- RetriesExhaustedException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
- RetriesExhaustedException(String, int, List<Throwable>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
Create a new RetriesExhaustedException from the list of prior failures.
- RetriesExhaustedException(int, List<RetriesExhaustedException.ThrowableWithExtraContext>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedException
-
Create a new RetriesExhaustedException from the list of prior failures.
- RetriesExhaustedException.ThrowableWithExtraContext - Class in org.apache.hadoop.hbase.client
-
Datastructure that allows adding more info around Throwable incident.
- RetriesExhaustedException.ThrowableWithExtraContext(Throwable, long, String) - Constructor for class org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
-
- RetriesExhaustedWithDetailsException - Exception in org.apache.hadoop.hbase.client
-
This subclass of
RetriesExhaustedException
is thrown when we have more information about which rows were causing which
exceptions on what servers.
- RetriesExhaustedWithDetailsException(List<Throwable>, List<Row>, List<String>) - Constructor for exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- retrievePassword(AuthenticationTokenIdentifier) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- RETRY_BACKOFF - Static variable in class org.apache.hadoop.hbase.HConstants
-
This is a retry backoff multiplier table similar to the BSD TCP syn
backoff table, a bit more aggressive than simple exponential backoff.
- RetryCounter - Class in org.apache.hadoop.hbase.util
-
- RetryCounter(int, int, TimeUnit) - Constructor for class org.apache.hadoop.hbase.util.RetryCounter
-
- RetryCounterFactory - Class in org.apache.hadoop.hbase.util
-
- RetryCounterFactory(int, int) - Constructor for class org.apache.hadoop.hbase.util.RetryCounterFactory
-
- returnCompressor(Compressor) - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
-
- returnDecompressor(Decompressor) - Method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
-
- ReusableStreamGzipCodec - Class in org.apache.hadoop.hbase.io.hfile
-
Fixes an inefficiency in Hadoop's Gzip codec, allowing to reuse compression
streams.
- ReusableStreamGzipCodec() - Constructor for class org.apache.hadoop.hbase.io.hfile.ReusableStreamGzipCodec
-
- ReusableStreamGzipCodec.ReusableGzipOutputStream - Class in org.apache.hadoop.hbase.io.hfile
-
A bridge that wraps around a DeflaterOutputStream to make it a
CompressionOutputStream.
- ReusableStreamGzipCodec.ReusableGzipOutputStream(OutputStream) - Constructor for class org.apache.hadoop.hbase.io.hfile.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
- revoke(UserPermission) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- revoke(byte[], TablePermission) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
Deprecated.
- revoke(UserPermission) - Method in interface org.apache.hadoop.hbase.security.access.AccessControllerProtocol
-
Revokes a previously granted privilege from a user or group.
- revoke(byte[], TablePermission) - Method in interface org.apache.hadoop.hbase.security.access.AccessControllerProtocol
-
- rewind() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Set position to beginning of given block
- rollback(Server, RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransaction
-
- rollback(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
Removes a kv from the memstore.
- rollbackRegionReplayEditsSize(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Roll back the global MemStore size for a specified region when this region
can't be opened.
- rollHLogWriter(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Roll the log writer.
- rollHLogWriter() - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Roll the log writer.
- rollHLogWriter() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- rollMetricsPeriod() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- rollWriter() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Roll the log writer.
- rollWriter(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Roll the log writer.
- ROOT_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
-
- ROOT_KEY_COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
-
- ROOT_REGIONINFO - Static variable in class org.apache.hadoop.hbase.HRegionInfo
-
HRegionInfo for root region
- ROOT_REGIONINFO - Static variable in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
HRegionInfo for root region
- ROOT_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
The root table's name.
- ROOT_TABLEDESC - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Table descriptor for -ROOT- catalog table
- rootBlockContainingKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Finds the root-level index block containing the given key.
- rootDir - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- rootDir - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- rootIndexSizeKB - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
The total size of block index root levels in this regionserver in KB.
- ROOTINDEXSIZEKB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- rootLocation - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- RootLocationEditor - Class in org.apache.hadoop.hbase.catalog
-
Makes changes to the location of -ROOT-
in ZooKeeper.
- RootLocationEditor() - Constructor for class org.apache.hadoop.hbase.catalog.RootLocationEditor
-
- rootRegion - Variable in class org.apache.hadoop.hbase.avro.generated.ATableDescriptor
-
- rootRegionExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks if root region exists
- RootRegionTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracks the root region server location node in zookeeper.
- RootRegionTracker(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.RootRegionTracker
-
Creates a root region location tracker.
- RootResource - Class in org.apache.hadoop.hbase.rest
-
- RootResource() - Constructor for class org.apache.hadoop.hbase.rest.RootResource
-
Constructor
- rootServerZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- roundRobinAssignment(List<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.DefaultLoadBalancer
-
Generates a bulk assignment plan to be used on cluster startup using a
simple round-robin assignment.
- roundRobinAssignment(List<HRegionInfo>, List<ServerName>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Perform a Round Robin assignment of regions.
- row - Variable in class org.apache.hadoop.hbase.avro.generated.ADelete
-
- row - Variable in class org.apache.hadoop.hbase.avro.generated.AGet
-
- row - Variable in class org.apache.hadoop.hbase.avro.generated.APut
-
- row - Variable in class org.apache.hadoop.hbase.avro.generated.AResult
-
- row - Variable in class org.apache.hadoop.hbase.client.Mutation
-
- Row - Interface in org.apache.hadoop.hbase.client
-
Has a row.
- row - Variable in class org.apache.hadoop.hbase.client.ServerCallable
-
- ROW - Static variable in interface org.apache.hadoop.hbase.coprocessor.example.BulkDeleteProtocol.DeleteType
-
Delete full row
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
row to increment
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Row to update
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
key of the row to be completely deleted.
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
key of the row to be completely deleted.
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Row to update
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
row key
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
row key
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
row key
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
row key
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
row key
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
row key
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
row key
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
row key
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
row key
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
row key
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
row key
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- row - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- row - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
row to check
- row - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
row to check
- row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- row - Variable in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- ROW_KEYS_PARAM_NAME - Static variable in class org.apache.hadoop.hbase.rest.MultiRowResource
-
- ROW_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Size of the row length field in bytes
- ROW_OFFSET - Static variable in class org.apache.hadoop.hbase.KeyValue
-
- rowBatches - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
list of row batches
- rowBatches - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
list of row batches
- rowCount(byte[], ColumnInterpreter<R, S>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
It gives the row count, by summing up the individual results obtained from
regions.
- 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() - Constructor for class org.apache.hadoop.hbase.filter.RowFilter
-
Writable constructor, do not use.
- RowFilter(CompareFilter.CompareOp, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.RowFilter
-
Constructor.
- rowIsInRange(HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Determines if the specified row is within the row range specified by the
specified HRegionInfo
- RowLock - Class in org.apache.hadoop.hbase.client
-
Deprecated.
RowLock
and associated operations are deprecated.
- RowLock(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.RowLock
-
Deprecated.
Creates a RowLock from a row and lock id
- RowLock(long) - Constructor for class org.apache.hadoop.hbase.client.RowLock
-
Deprecated.
Creates a RowLock with only a lock id
- RowModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a row.
- RowModel() - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
-
Default constructor
- RowModel(String) - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
-
Constructor
- RowModel(byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
-
Constructor
- RowModel(String, List<CellModel>) - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
-
Constructor
- RowModel(byte[], List<CellModel>) - Constructor for class org.apache.hadoop.hbase.rest.model.RowModel
-
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.
- rowMutations - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
mutations to apply
- rowMutationsFromThrift(TRowMutations) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- RowResource - Class in org.apache.hadoop.hbase.rest
-
- RowResource(TableResource, String, String, String) - Constructor for class org.apache.hadoop.hbase.rest.RowResource
-
Constructor
- rowResultFromHBase(Result[], boolean) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a list of Thrift TRowResult "struct" based on
an Hbase RowResult object.
- rowResultFromHBase(Result[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a list of Thrift TRowResult "struct" based on
an array of Hbase RowResult objects.
- rowResultFromHBase(Result) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
- RowResultGenerator - Class in org.apache.hadoop.hbase.rest
-
- RowResultGenerator(String, RowSpec, Filter) - Constructor for class org.apache.hadoop.hbase.rest.RowResultGenerator
-
- rows - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
row keys
- rows - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
row keys
- rows - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
row keys
- rows - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
row keys
- ROWS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- RowSpec - Class in org.apache.hadoop.hbase.rest
-
Parses a path based row/column/timestamp specification into its component
elements.
- RowSpec(String) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
-
- RowSpec(byte[], byte[], byte[][], long, long, int) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
-
- RowSpec(byte[], byte[], Collection<byte[]>, long, long, int) - Constructor for class org.apache.hadoop.hbase.rest.RowSpec
-
- rowToStr(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- rowToStr(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
- rowToStr(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- RPAREN - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for RPAREN
- RPC_ENGINE_PROP - Static variable in class org.apache.hadoop.hbase.ipc.HBaseRPC
-
Configuration key for the
RpcEngine
implementation to load to
handle connection protocols.
- RpcCallContext - Interface in org.apache.hadoop.hbase.ipc
-
- RpcEngine - Interface in org.apache.hadoop.hbase.ipc
-
An RPC implementation.
- rpcMetrics - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- rpcProcessingTime - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- rpcQueueTime - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- rpcs - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- RpcServer - Interface in org.apache.hadoop.hbase.ipc
-
- rpcSlowResponseTime - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- RSDumpServlet - Class in org.apache.hadoop.hbase.regionserver
-
- RSDumpServlet() - Constructor for class org.apache.hadoop.hbase.regionserver.RSDumpServlet
-
- rsServices - Variable in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
- RSStatusServlet - Class in org.apache.hadoop.hbase.regionserver
-
- RSStatusServlet() - Constructor for class org.apache.hadoop.hbase.regionserver.RSStatusServlet
-
- RSStatusTmpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- RSStatusTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- RSStatusTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- RSStatusTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- RSStatusTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- RSStatusTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.regionserver
-
- RSStatusTmplImpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- RSStatusTmplImpl(TemplateManager, RSStatusTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmplImpl
-
- rsZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- run() - Method in class org.apache.hadoop.hbase.Chore
-
- run() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- 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() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- run() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Responder
-
- 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.hadoopbackport.InputSampler
-
Driver for InputSampler from the command line.
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- run(Mapper<ImmutableBytesWritable, Result, K2, V2>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Run the application's maps using a thread pool.
- run(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
- run() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Main processing loop for the HMaster.
- run() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
-
- run(String[]) - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- run() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache.RefreshCacheTask
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- run(String[]) - Method in class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
The HRegionServer sticks in this loop until closed.
- run(String[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.HRegionThriftServer
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
- run() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
- 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() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- run(String[]) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
- 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() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
-
- run() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
-
- run(String[]) - Method in class org.apache.hadoop.hbase.tool.Canary
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- run() - Method in class org.apache.hadoop.hbase.util.HasThread
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- run(String[]) - Method in class org.apache.hadoop.hbase.util.Merge
-
- RUN_SHUTDOWN_HOOK - Static variable in class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
Key for boolean configuration whose default is true.
- runAs(PrivilegedAction<T>) - Method in class org.apache.hadoop.hbase.security.User
-
Executes the given action within the context of this user.
- runAs(PrivilegedExceptionAction<T>) - Method in class org.apache.hadoop.hbase.security.User
-
Executes the given action within the context of this user.
- runAs(PrivilegedAction<T>) - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- runAs(PrivilegedExceptionAction<T>) - Method in class org.apache.hadoop.hbase.security.User.SecureHadoopUser
-
- running - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- running - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- S - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'S'
- SASL_DEFAULT_REALM - Static variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- SASL_PROPS - Static variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- saslConnect(InputStream, OutputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Do client side SASL authentication with server via the given InputStream
and OutputStream
- saslQop - Variable in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.QualityOfProtection
-
- saveMetadata(HFile.Writer) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Save metadata in HFile which will be written to disk
- saveMetadata(HFile.Writer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- saveMetadata(HFile.Writer) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- 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(byte[], Scan, int) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Perform scan operation.
- SCAN - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Base-64 encoded scanner.
- scan(byte[], Scan, int) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- scan - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Scan instance
- scan - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
the scan object to get a Scanner for
- scan - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
the scan object to get a Scanner for
- 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_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_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 to scan.
- 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_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.
- ScanDeleteTracker - Class in org.apache.hadoop.hbase.regionserver
-
This class is responsible for the tracking and enforcement of Deletes
during the course of a Scan operation.
- ScanDeleteTracker() - Constructor for class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
Constructor for ScanDeleteTracker
- scanFromThrift(TScan) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- scanMetaRegion(HRegion, MetaUtils.ScannerListener) - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
Scan the passed in metaregion m
invoking the passed
listener
per row found.
- scanMetaRegion(HRegionInfo, MetaUtils.ScannerListener) - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
Scans a meta region.
- scanMetrics - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- ScanMetrics - Class in org.apache.hadoop.hbase.client.metrics
-
Provides client-side metrics related to scan operations
The data can be passed to mapreduce framework or other systems.
- ScanMetrics() - Constructor for class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
constructor
- scannerCaching - Variable in class org.apache.hadoop.hbase.client.HTable
-
- ScannerCallable - Class in org.apache.hadoop.hbase.client
-
Retries scanner operations such as create, next, etc.
- ScannerCallable(HConnection, byte[], Scan, ScanMetrics) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
-
- scannerClose(int) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- scannerClose(int, Callback<Void>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- scannerClose(int) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- scannerClose(int, AsyncMethodCallback<Hbase.AsyncClient.scannerClose_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerClose(int, AsyncMethodCallback<Hbase.AsyncClient.scannerClose_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerClose(int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Closes the server-state associated with an open scanner.
- scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerGet(int, AsyncMethodCallback<Hbase.AsyncClient.scannerGet_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerGet(int, AsyncMethodCallback<Hbase.AsyncClient.scannerGet_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerGet(int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Returns the scanner's current row value and advances to the next
row in the table.
- scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerGetList(int, int, AsyncMethodCallback<Hbase.AsyncClient.scannerGetList_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerGetList(int, int, AsyncMethodCallback<Hbase.AsyncClient.scannerGetList_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerGetList(int, int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Returns, starting at the scanner's current row value nbRows worth of
rows and advances to the next row in the table.
- scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerGetRows(int, int) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- scannerGetRows(int, int, Callback<List<AResult>>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- scannerGetRows(int, int) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- scannerId - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
the Id of the Scanner to close *
- scannerId - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
the Id of the Scanner to return rows from.
- ScannerInstanceResource - Class in org.apache.hadoop.hbase.rest
-
- ScannerInstanceResource() - Constructor for class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- ScannerInstanceResource(String, String, ResultGenerator, int) - Constructor for class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- scannerMap - Variable in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- scannerMap - Variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- ScannerMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ScannerMessage.Scanner - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ScannerMessage.Scanner.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ScannerMessage.ScannerOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ScannerModel - Class in org.apache.hadoop.hbase.rest.model
-
A representation of Scanner parameters.
- ScannerModel() - Constructor for class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Default constructor
- ScannerModel(byte[], byte[], List<byte[]>, int, long, int, String) - Constructor for class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Constructor
- ScannerModel(byte[], byte[], List<byte[]>, int, long, long, String) - Constructor for class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Constructor
- scannerOpen(ByteBuffer, AScan) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- scannerOpen(ByteBuffer, AScan, Callback<Integer>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- scannerOpen(ByteBuffer, AScan) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpen_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpen_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get a scanner on the current table starting at the specified row and
ending at the last row in the table.
- scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get a scanner on the current table starting at the specified row and
ending at the last row in the table.
- scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithPrefix_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithPrefix_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Open a scanner for a given prefix.
- scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithScan_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithScan_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get a scanner on the current table, using the Scan instance
for the scan parameters.
- scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStop_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStop_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get a scanner on the current table starting and stopping at the
specified rows.
- scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStopTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStopTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get a scanner on the current table starting and stopping at the
specified rows.
- scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- ScannerResource - Class in org.apache.hadoop.hbase.rest
-
- ScannerResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResource
-
Constructor
- ScannerResultGenerator - Class in org.apache.hadoop.hbase.rest
-
- ScannerResultGenerator(String, RowSpec, Filter) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- ScannerTimeoutException - Exception in org.apache.hadoop.hbase.client
-
Thrown when a scanner has timed out.
- ScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver
-
A query matcher that is specifically designed for the scan case.
- ScanQueryMatcher(Scan, Store.ScanInfo, NavigableSet<byte[]>, ScanType, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
Construct a QueryMatcher for a scan
- ScanQueryMatcher.MatchCode - Enum in org.apache.hadoop.hbase.regionserver
-
- scanRootRegion(MetaUtils.ScannerListener) - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
Scans the root region.
- SCANS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Job parameter that specifies the scan list.
- ScanType - Enum in org.apache.hadoop.hbase.regionserver
-
Enum to distinguish general scan types.
- ScanWildcardColumnTracker - Class in org.apache.hadoop.hbase.regionserver
-
Keeps track of the columns for a scan if they are not explicitly specified
- ScanWildcardColumnTracker(int, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
Return maxVersions of every row.
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.AClusterStatus
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.AColumn
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.AColumnValue
-
- SCHEMA$ - Static variable in enum org.apache.hadoop.hbase.avro.generated.ACompressionAlgorithm
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.ADelete
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.AFamilyDescriptor
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.AGet
-
- SCHEMA$ - Static variable in exception org.apache.hadoop.hbase.avro.generated.AIllegalArgument
-
- SCHEMA$ - Static variable in exception org.apache.hadoop.hbase.avro.generated.AIOError
-
- SCHEMA$ - Static variable in exception org.apache.hadoop.hbase.avro.generated.AMasterNotRunning
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.APut
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.ARegionLoad
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.AResult
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.AResultEntry
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.AScan
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.AServerAddress
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.AServerInfo
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.AServerLoad
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.ATableDescriptor
-
- SCHEMA$ - Static variable in exception org.apache.hadoop.hbase.avro.generated.ATableExists
-
- SCHEMA$ - Static variable in class org.apache.hadoop.hbase.avro.generated.ATimeRange
-
- SCHEMA_CONFIGURED_UNALIGNED_HEAP_SIZE - Static variable in class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
Estimated heap size of this object.
- schemaConfAsJSON() - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
- schemaConfigurationChanged() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- schemaConfigurationChanged() - Method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
A hook method called when schema configuration changes.
- schemaConfigurationChanged() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- SchemaConfigured - Class in org.apache.hadoop.hbase.regionserver.metrics
-
A base class for objects that are associated with a particular table and
column family.
- SchemaConfigured() - Constructor for class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
Default constructor.
- SchemaConfigured(Configuration, Path) - Constructor for class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
Initialize table and column family name from an HFile path.
- SchemaConfigured(Path) - Constructor for class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
Used when we know an HFile path to deduce table and CF name from, but do
not have a configuration.
- SchemaConfigured(Configuration, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
Used when we know table and column family name.
- SchemaConfigured(SchemaMetrics.SchemaAware) - Constructor for class org.apache.hadoop.hbase.regionserver.metrics.SchemaConfigured
-
- SchemaMetrics - Class in org.apache.hadoop.hbase.regionserver.metrics
-
A collection of metric names in a given column family or a (table, column
family) combination.
- SchemaMetrics.BlockMetricType - Enum in org.apache.hadoop.hbase.regionserver.metrics
-
- SchemaMetrics.SchemaAware - Interface in org.apache.hadoop.hbase.regionserver.metrics
-
- SchemaMetrics.StoreMetricType - Enum in org.apache.hadoop.hbase.regionserver.metrics
-
- SchemaResource - Class in org.apache.hadoop.hbase.rest
-
- SchemaResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.SchemaResource
-
Constructor
- second - Variable in class org.apache.hadoop.hbase.util.Pair
-
- secretManager - Variable in class org.apache.hadoop.hbase.ipc.SecureServer
-
- SecureBulkLoadClient - Class in org.apache.hadoop.hbase.coprocessor
-
- SecureBulkLoadClient(HTable) - Constructor for class org.apache.hadoop.hbase.coprocessor.SecureBulkLoadClient
-
- SecureBulkLoadClient(HTable, byte[]) - Constructor for class org.apache.hadoop.hbase.coprocessor.SecureBulkLoadClient
-
- SecureBulkLoadEndpoint - Class in org.apache.hadoop.hbase.security.access
-
Coprocessor service for bulk loads in secure mode.
- SecureBulkLoadEndpoint() - Constructor for class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- SecureBulkLoadProtocol - Interface in org.apache.hadoop.hbase.security.access
-
Provides a secure way to bulk load data onto HBase
These are internal API.
- SecureClient - Class in org.apache.hadoop.hbase.ipc
-
A client for an IPC service, which support SASL authentication of connections
using either GSSAPI for Kerberos authentication or DIGEST-MD5 for
authentication using signed tokens.
- SecureClient(Class<? extends Writable>, Configuration, SocketFactory, UserProvider) - Constructor for class org.apache.hadoop.hbase.ipc.SecureClient
-
Construct an IPC client whose values are of the given Writable
class.
- SecureClient(Class<? extends Writable>, Configuration, UserProvider) - Constructor for class org.apache.hadoop.hbase.ipc.SecureClient
-
Construct an IPC client with the default SocketFactory
- SecureClient.SecureConnection - Class in org.apache.hadoop.hbase.ipc
-
Thread that reads responses and notifies callers.
- SecureClient.SecureConnection(HBaseClient.ConnectionId) - Constructor for class org.apache.hadoop.hbase.ipc.SecureClient.SecureConnection
-
- SecureRpcEngine - Class in org.apache.hadoop.hbase.ipc
-
A loadable RPC engine supporting SASL authentication of connections, using
GSSAPI for Kerberos authentication or DIGEST-MD5 for authentication via
signed tokens.
- SecureRpcEngine() - Constructor for class org.apache.hadoop.hbase.ipc.SecureRpcEngine
-
- SecureRpcEngine.Server - Class in org.apache.hadoop.hbase.ipc
-
An RPC Server.
- SecureRpcEngine.Server(Object, Class<?>[], Configuration, String, int, int, int, boolean, int) - Constructor for class org.apache.hadoop.hbase.ipc.SecureRpcEngine.Server
-
Construct an RPC server.
- SecureServer - Class in org.apache.hadoop.hbase.ipc
-
An abstract IPC service, supporting SASL authentication of connections,
using GSSAPI for Kerberos authentication or DIGEST-MD5 for authentication
via signed tokens.
- SecureServer(String, int, Class<? extends Writable>, int, int, Configuration, String, int) - Constructor for class org.apache.hadoop.hbase.ipc.SecureServer
-
Constructs a server listening on the named port and address.
- SecureServer.SecureCall - Class in org.apache.hadoop.hbase.ipc
-
- SecureServer.SecureCall(int, Writable, HBaseServer.Connection, HBaseServer.Responder, long) - Constructor for class org.apache.hadoop.hbase.ipc.SecureServer.SecureCall
-
- SecureServer.SecureConnection - Class in org.apache.hadoop.hbase.ipc
-
Reads calls from a connection and queues them for handling.
- SecureServer.SecureConnection(SocketChannel, long) - Constructor for class org.apache.hadoop.hbase.ipc.SecureServer.SecureConnection
-
- seek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
Seeks all scanners at or below the specified seek key.
- seek(KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Seek the scanner at or after the specified KeyValue.
- seek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
-
Set the scanner at the seek key.
- seek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- seek(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- seek(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Reader
-
- seek(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- seek() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
-
Advance the reader to the current position
- seek(KeyValue) - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- seekAtOrAfter(HFileScanner, KeyValue) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- seekBefore(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- seekBefore(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.AbstractScannerV1
-
- seekBefore(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- seekBefore(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Consider the key stream of all the keys in the file,
k[0] ..
- seekBefore(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- seekTo(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- seekTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.AbstractScannerV1
-
- seekTo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV1.ScannerV1
-
- seekTo(byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
An internal API function.
- seekTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- seekTo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- seekTo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
Positions this scanner at the start of the file.
- seekTo(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
SeekTo or just before the passed key
.
- seekTo(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- seekTo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Positions this scanner at the start of the file.
- seekToDataBlock(byte[], int, int, HFileBlock, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Return the data block which contains this key.
- seekToKeyInBlock(byte[], int, int, boolean) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Moves the seeker position within the current block to:
the last key that that is less than or equal to the given key if
seekBefore
is false
the last key that is strictly less than the given key if
seekBefore
is true.
- selectExpiredStoreFilesToCompact(long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactSelection
-
Select the expired store files to compact
- SELECTOR_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Number of selector threads for reading and writing socket
- selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
-
- send_atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_closeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_compact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_deleteMultiple(ByteBuffer, List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_deleteSingle(ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_deleteTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_disableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_enableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_exists(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_get(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_getColumnDescriptors(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getMultiple(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_getRegionInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getScannerResults(ByteBuffer, TScan, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_getScannerRows(int, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_getTableNames() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getTableRegions(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_increment(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_increment(ByteBuffer, TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_incrementRows(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_isTableEnabled(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_majorCompact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_mutateRow(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_mutateRow(ByteBuffer, TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_mutateRows(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_mutateRowsTs(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_mutateRowTs(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_openScanner(ByteBuffer, TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_put(ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_putMultiple(ByteBuffer, List<TPut>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- sendAbortToMembers(Procedure, ForeignException) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify the members that the coordinator has aborted the procedure and that it should release
barrier resources.
- sendAbortToMembers(Procedure, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
This is the abort message being sent by the coordinator to member
TODO this code isn't actually used but can be used to issue a cancellation from the
coordinator.
- sendError(int, String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- sendError(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- sendGlobalBarrierAcquire(Procedure, byte[], List<String>) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify the members to acquire barrier for the procedure
- sendGlobalBarrierAcquire(Procedure, byte[], List<String>) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
The "acquire" phase.
- sendGlobalBarrierComplete() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- sendGlobalBarrierReached() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Sends a message to all members that the global barrier condition has been satisfied.
- sendGlobalBarrierReached(Procedure, List<String>) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify members that all members have acquired their parts of the barrier and that they can
now execute under the global barrier.
- sendGlobalBarrierReached(Procedure, List<String>) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
- sendGlobalBarrierStart() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- sendMemberAborted(Subprocedure, ForeignException) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Notify the coordinator that we aborted the specified
Subprocedure
- sendMemberAborted(Subprocedure, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
This should be called by the member and should write a serialized root cause exception as
to the abort znode.
- sendMemberAcquired(Subprocedure) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Notify the coordinator that the specified
Subprocedure
has acquired the locally required
barrier condition.
- sendMemberAcquired(Subprocedure) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
This attempts to create an acquired state znode for the procedure (snapshot name).
- sendMemberCompleted(Subprocedure) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Notify the coordinator that the specified
Subprocedure
has completed the work that
needed to be done under the global barrier.
- sendMemberCompleted(Subprocedure) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
This acts as the ack for a completed snapshot
- sendParam(HBaseClient.Call) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- sendPing() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- sendRedirect(String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- sendRegionClose(ServerName, HRegionInfo, int) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends an CLOSE RPC to the specified server to close the specified region.
- sendRegionOpen(ServerName, HRegionInfo, int) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends an OPEN RPC to the specified server to open the specified region.
- sendRegionOpen(ServerName, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends an OPEN RPC to the specified server to open the specified region.
- sendResponseIfReady() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
If we have a response, and delay is not set, then respond
immediately.
- sentBytes - Variable in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- SEPARATE_HLOG_FOR_META - Static variable in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- separator() - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
- separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- seqids - Static variable in class org.apache.hadoop.hbase.executor.EventHandler
-
- SequenceFileLogReader - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SequenceFileLogReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
Default constructor.
- SequenceFileLogReader(Class<? extends HLogKey>) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
This constructor allows a specific HLogKey implementation to override that
which would otherwise be chosen via configuration property.
- SequenceFileLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
-
Implementation of
HLog.Writer
that delegates to
SequenceFile.Writer.
- SequenceFileLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
-
Default constructor.
- SequenceFileLogWriter(Class<? extends HLogKey>) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
-
This constructor allows a specific HLogKey implementation to override that
which would otherwise be chosen via configuration property.
- sequenceID - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- sequenceNumber - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- serialize(String, Throwable) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Converts a ForeignException to an array of bytes.
- serialize(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Serializes its data into destination.
- serialize(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- serializeRegionInfo(DataOutput) - Method in class org.apache.hadoop.hbase.client.HTable
-
Serialize the regions information of this table and output
to out
.
- serve() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- server - Variable in class org.apache.hadoop.hbase.client.ServerCallable
-
- server - Variable in class org.apache.hadoop.hbase.executor.EventHandler
-
- SERVER - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- server - Variable in class org.apache.hadoop.hbase.master.BulkAssigner
-
- Server - Interface in org.apache.hadoop.hbase
-
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
- SERVER_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The server column qualifier
- serverAddress - Variable in class org.apache.hadoop.hbase.avro.generated.AServerInfo
-
- ServerCallable<T> - Class in org.apache.hadoop.hbase.client
-
Abstract class that implements
Callable
.
- ServerCallable(HConnection, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.ServerCallable
-
- ServerCallable(HConnection, byte[], byte[], int) - Constructor for class org.apache.hadoop.hbase.client.ServerCallable
-
- ServerCommandLine - Class in org.apache.hadoop.hbase.util
-
Base class for command lines that start up various HBase daemons.
- ServerCommandLine() - Constructor for class org.apache.hadoop.hbase.util.ServerCommandLine
-
- serverInfos - Variable in class org.apache.hadoop.hbase.avro.generated.AClusterStatus
-
- serverManager - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- ServerManager - Class in org.apache.hadoop.hbase.master
-
The ServerManager class manages info about region servers.
- ServerManager(Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.ServerManager
-
Constructor.
- serverManager - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- serverName - Variable in class org.apache.hadoop.hbase.avro.generated.AServerInfo
-
- serverName - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- ServerName - Class in org.apache.hadoop.hbase
-
Instance of an HBase ServerName.
- ServerName(String, int, long) - Constructor for class org.apache.hadoop.hbase.ServerName
-
- ServerName(String) - Constructor for class org.apache.hadoop.hbase.ServerName
-
- ServerName(String, long) - Constructor for class org.apache.hadoop.hbase.ServerName
-
- serverName - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- SERVERNAME_PATTERN - Static variable in class org.apache.hadoop.hbase.ServerName
-
- SERVERNAME_SEPARATOR - Static variable in class org.apache.hadoop.hbase.ServerName
-
This character is used as separator between server hostname, port and
startcode.
- ServerNotRunningYetException - Exception in org.apache.hadoop.hbase.ipc
-
- ServerNotRunningYetException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
-
- servers - Variable in class org.apache.hadoop.hbase.avro.generated.AClusterStatus
-
- servers - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- ServerShutdownHandler - Class in org.apache.hadoop.hbase.master.handler
-
Process server shutdown.
- ServerShutdownHandler(Server, MasterServices, DeadServer, ServerName, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- SERVERVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- services - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- services - Static variable in class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- set(Object) - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
Reset the instance.
- 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(User, InetAddress, Class<? extends VersionedProtocol>) - Static method in class org.apache.hadoop.hbase.ipc.RequestContext
-
Initializes the client credentials for the current request.
- setAdmin(HBaseAdmin) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setAgeOfLastAppliedOp(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkMetrics
-
Set the age of the last edit that was applied
- setAgeOfLastShippedOp(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceMetrics
-
Set the age of the last edit that was shipped
- setAmmount(long) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setAmmountIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setAmount(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setAmountIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- 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
-
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Delete attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Delete attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Delete attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Delete attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Mutation attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
Mutation attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Mutation attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Mutation attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Scan attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Scan attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Scan attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Scan attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Scan attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Scan attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- setAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- setAttrs(int, TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- setAttrs(int, TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
- 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
-
- 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
-
- setAverageLoad(double) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setAverageLoad(double) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- 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()
- setBatch(int) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setBatch(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- setBatchSize(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setBatchSizeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
-
- setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBlockCacheEnabledIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBlocks(int) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- setBlocksize(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setBloomFilterNbHashes(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBloomFilterNbHashesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBloomFilterType(StoreFile.BloomType) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setBloomFilterType(String) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBloomFilterTypeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBloomFilterVectorSize(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBloomFilterVectorSizeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- 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
-
- setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Only used for testing.
- setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the number of rows for caching that will be passed to scanners.
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Set the number of rows that will be fetched on next
- setCaching(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setCaching(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setCachingIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setCachingIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setCallQueueLen(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- setCatalogJanitorEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Switch for the background CatalogJanitor thread.
- setCell(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- setCellIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- 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.
- setCheckHdfs(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setClassName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- setClose() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Call this when the next invocation of call should close the scanner
- setCluster(Cluster) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
- setClusterDown() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Sets the cluster as down by deleting the znode.
- setClusterId(UUID) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the replication custer id.
- setClusterId(UUID) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Set the cluster id of this key
- setClusterId(FileSystem, Path, String, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Writes a new unique identifier for this cluster to the "hbase.id" file
in the HBase root directory
- setClusterId(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ClusterId
-
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Marks that the clusters with the given clusterIds have consumed the mutation
- setClusterStatus(ClusterStatus) - Method in class org.apache.hadoop.hbase.master.DefaultLoadBalancer
-
- setClusterStatus(ClusterStatus) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Set the current cluster status.
- setClusterUp() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Sets the cluster as up.
- setCode(int) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- setCodec(WALEditCodec) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- setColumn(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
name of column
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
name of column whose value is to be deleted
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
name of column whose value is to be deleted
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
column name
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
column name
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
column name
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setColumnFamilies(List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
list of column family descriptors
- setColumnFamiliesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- setColumnFamily(String) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setColumnName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- setColumnName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- setColumnNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- setColumns(List<byte[]>) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setColumns(List<ColumnSchemaModel>) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- setColumns(int, ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- setColumns(int, ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- setColumns(int, ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
List of columns to return, null for all columns
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
List of columns to return, null for all columns
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
List of columns to return, null for all columns
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
List of columns to return, null for all columns
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
columns to scan.
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
columns to scan.
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
the columns you want returned
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
columns to scan.
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
columns to scan.
- setColumns(Map<ByteBuffer, TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setColumns(List<TColumn>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setColumns(List<TColumn>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setColumns(List<TColumnIncrement>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setColumns(List<TColumn>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setColumnValues(List<TColumnValue>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setColumnValues(List<TColumnValue>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- setColumnValuesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setColumnValuesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Compression types supported in hbase.
- setComparatorClass(Class<? extends RawComparator>) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setCompression(CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEditCodec
-
- setCompression(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- setCompression(String) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setCompressionCodec(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
- setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- setCompressionIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
-
- setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Compression types supported in hbase.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.BaseConfigurable
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.ipc.Invocation
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.ipc.SecureRpcEngine
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.TotalOrderPartitioner
-
Read in the partition file and build indexing data structures.
- 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
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.DefaultLoadBalancer
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
This method should only be called once, as it starts a thread to keep the cache
up-to-date.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.tool.Canary
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- setConfiguration(HTableDescriptor, Class<? extends Constraint>, Configuration) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Update the configuration for the
Constraint
; does not change the
order in which the constraint is run.
- setConfigure(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
- setConnection(String, int) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- setConnection(String, int) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Registers current handler client details.
- setContentLength(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- setCoprocessorHost(RegionCoprocessorHost) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setCorePoolSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- setCorePoolSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- setCount(int) - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Set the current count to a new count
- setCreationTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- setCurrentBuffer(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Set on which buffer there will be done seeking.
- setCurrentCompactedKVs(long) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- setCurrentCompactedKVs(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setCurrentCompactedKVs(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setDaemon(boolean) - Method in class org.apache.hadoop.hbase.util.HasThread
-
- setDaemonThreadRunning(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Utility method that sets name, daemon status and starts passed thread.
- setDaemonThreadRunning(Thread, String) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Utility method that sets name, daemon status and starts passed thread.
- setDaemonThreadRunning(Thread, String, Thread.UncaughtExceptionHandler) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Utility method that sets name, daemon status and starts passed thread.
- setData(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- setData(String, byte[], int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
setData is NOT an idempotent operation.
- setData(ZooKeeperWatcher, String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Sets the data of the existing znode to be the specified data.
- setData(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Sets the data of the existing znode to be the specified data.
- setData(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set data block encoding algorithm used in block cache.
- setDataIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setDeadNodes(List<String>) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setDeadNodes(int, String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- setDeadServers(Set<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setDeadServers(Set<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setDeclaringClass(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- setDefaultClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- setDeferredLogFlush(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
This is used to defer the log edits syncing to the file system.
- setDeletedTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Deletes the table in zookeeper.
- setDeleteFamilyBloomFilterFaulty() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- setDeletes(List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
list of TDeletes to delete
- setDeleteSingle(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
the TDelete to execute if the check succeeds
- setDeleteSingle(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
the TDelete to delete
- setDeleteSingle(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- setDeleteSingleIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setDeleteSingleIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- setDeletesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- setDeleteType(TDeleteType) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setDeleteTypeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setDescription(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- setDestination(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Set the destination server for the plan for this region.
- setDisabledTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the specified table as DISABLED in zookeeper.
- setDisablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the specified table as DISABLING in zookeeper.
- setDisplayFullReport() - 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(TDurability) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setDurability(TDurability) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setDurabilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setDurabilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setEnabledTable(String) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- setEnabledTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the ENABLED state in the cache and creates or force updates a node to
ENABLED state for the specified table
- setEnablingTable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTable
-
Sets the specified table as ENABLING in zookeeper.
- setEncodeOnDisk(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set the flag indicating that we only want to encode data block in cache
but not on disk.
- setEndKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- setEndKey(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setEndKey(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- setEndKey(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setEndKey(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setEndKeyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setEndRow(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- setEntryCount(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setErrorHandler(HBaseRPCErrorHandler) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Set the handler for calling out of RPC for error conditions.
- setErrorHandler(HBaseRPCErrorHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
-
- setErrorInfo(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setEvictOnClose(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Only used for testing.
- setException(IOException) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Call
-
Set the exception when there is an error.
- setExist(AlreadyExists) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setExistIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setExpiration(long) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- setFakeLookupMode(boolean) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
column name
- setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
column family to check
- setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
column family to check
- setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setFamilyMap(Map<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for setting the put's familyMap
- setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - Method in class org.apache.hadoop.hbase.client.Scan
-
Setting the familyMap
- setFieldValue(AlreadyExists._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- setFieldValue(BatchMutation._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- setFieldValue(ColumnDescriptor._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setFieldValue(Hbase.atomicIncrement_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setFieldValue(Hbase.atomicIncrement_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setFieldValue(Hbase.compact_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- setFieldValue(Hbase.compact_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- setFieldValue(Hbase.createTable_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- setFieldValue(Hbase.createTable_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setFieldValue(Hbase.deleteAll_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setFieldValue(Hbase.deleteAll_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- setFieldValue(Hbase.deleteAllRow_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- setFieldValue(Hbase.deleteAllRow_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- setFieldValue(Hbase.deleteAllRowTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setFieldValue(Hbase.deleteAllRowTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- setFieldValue(Hbase.deleteAllTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setFieldValue(Hbase.deleteAllTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- setFieldValue(Hbase.deleteTable_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- setFieldValue(Hbase.deleteTable_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- setFieldValue(Hbase.disableTable_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- setFieldValue(Hbase.disableTable_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- setFieldValue(Hbase.enableTable_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- setFieldValue(Hbase.enableTable_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- setFieldValue(Hbase.get_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setFieldValue(Hbase.get_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- setFieldValue(Hbase.getColumnDescriptors_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- setFieldValue(Hbase.getColumnDescriptors_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- setFieldValue(Hbase.getRegionInfo_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- setFieldValue(Hbase.getRegionInfo_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- setFieldValue(Hbase.getRow_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- setFieldValue(Hbase.getRow_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- setFieldValue(Hbase.getRowOrBefore_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setFieldValue(Hbase.getRowOrBefore_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- setFieldValue(Hbase.getRows_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- setFieldValue(Hbase.getRows_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- setFieldValue(Hbase.getRowsTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- setFieldValue(Hbase.getRowsTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- setFieldValue(Hbase.getRowsWithColumns_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- setFieldValue(Hbase.getRowsWithColumns_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- setFieldValue(Hbase.getRowsWithColumnsTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setFieldValue(Hbase.getRowsWithColumnsTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- setFieldValue(Hbase.getRowTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setFieldValue(Hbase.getRowTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- setFieldValue(Hbase.getRowWithColumns_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setFieldValue(Hbase.getRowWithColumns_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- setFieldValue(Hbase.getRowWithColumnsTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setFieldValue(Hbase.getRowWithColumnsTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- setFieldValue(Hbase.getTableNames_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- setFieldValue(Hbase.getTableNames_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- setFieldValue(Hbase.getTableRegions_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- setFieldValue(Hbase.getTableRegions_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- setFieldValue(Hbase.getVer_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setFieldValue(Hbase.getVer_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- setFieldValue(Hbase.getVerTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setFieldValue(Hbase.getVerTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- setFieldValue(Hbase.increment_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- setFieldValue(Hbase.increment_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- setFieldValue(Hbase.incrementRows_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- setFieldValue(Hbase.incrementRows_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- setFieldValue(Hbase.isTableEnabled_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- setFieldValue(Hbase.isTableEnabled_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- setFieldValue(Hbase.majorCompact_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- setFieldValue(Hbase.majorCompact_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- setFieldValue(Hbase.mutateRow_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setFieldValue(Hbase.mutateRow_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- setFieldValue(Hbase.mutateRows_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- setFieldValue(Hbase.mutateRows_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- setFieldValue(Hbase.mutateRowsTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- setFieldValue(Hbase.mutateRowsTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- setFieldValue(Hbase.mutateRowTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setFieldValue(Hbase.mutateRowTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- setFieldValue(Hbase.scannerClose_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- setFieldValue(Hbase.scannerClose_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- setFieldValue(Hbase.scannerGet_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- setFieldValue(Hbase.scannerGet_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setFieldValue(Hbase.scannerGetList_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- setFieldValue(Hbase.scannerGetList_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setFieldValue(Hbase.scannerOpen_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setFieldValue(Hbase.scannerOpen_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- setFieldValue(Hbase.scannerOpenTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setFieldValue(Hbase.scannerOpenTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- setFieldValue(Hbase.scannerOpenWithPrefix_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setFieldValue(Hbase.scannerOpenWithPrefix_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- setFieldValue(Hbase.scannerOpenWithScan_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- setFieldValue(Hbase.scannerOpenWithScan_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- setFieldValue(Hbase.scannerOpenWithStop_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setFieldValue(Hbase.scannerOpenWithStop_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- setFieldValue(Hbase.scannerOpenWithStopTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setFieldValue(Hbase.scannerOpenWithStopTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- setFieldValue(IllegalArgument._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- setFieldValue(IOError._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- setFieldValue(Mutation._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setFieldValue(TCell._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- setFieldValue(TColumn._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- setFieldValue(TIncrement._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setFieldValue(TRegionInfo._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setFieldValue(TRowResult._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setFieldValue(TScan._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setFieldValue(TColumn._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setFieldValue(TColumnIncrement._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setFieldValue(TColumnValue._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setFieldValue(TDelete._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setFieldValue(TGet._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setFieldValue(THBaseService.checkAndDelete_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setFieldValue(THBaseService.checkAndDelete_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- setFieldValue(THBaseService.checkAndPut_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setFieldValue(THBaseService.checkAndPut_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- setFieldValue(THBaseService.closeScanner_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- setFieldValue(THBaseService.closeScanner_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- setFieldValue(THBaseService.deleteMultiple_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- setFieldValue(THBaseService.deleteMultiple_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- setFieldValue(THBaseService.deleteSingle_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- setFieldValue(THBaseService.deleteSingle_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- setFieldValue(THBaseService.exists_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- setFieldValue(THBaseService.exists_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- setFieldValue(THBaseService.get_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- setFieldValue(THBaseService.get_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- setFieldValue(THBaseService.getMultiple_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- setFieldValue(THBaseService.getMultiple_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- setFieldValue(THBaseService.getScannerResults_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- setFieldValue(THBaseService.getScannerResults_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- setFieldValue(THBaseService.getScannerRows_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- setFieldValue(THBaseService.getScannerRows_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- setFieldValue(THBaseService.increment_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- setFieldValue(THBaseService.increment_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- setFieldValue(THBaseService.mutateRow_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- setFieldValue(THBaseService.mutateRow_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- setFieldValue(THBaseService.openScanner_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- setFieldValue(THBaseService.openScanner_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- setFieldValue(THBaseService.put_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- setFieldValue(THBaseService.put_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- setFieldValue(THBaseService.putMultiple_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- setFieldValue(THBaseService.putMultiple_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- setFieldValue(TIllegalArgument._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- setFieldValue(TIncrement._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setFieldValue(TIOError._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- setFieldValue(TPut._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setFieldValue(TResult._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- setFieldValue(TRowMutations._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- setFieldValue(TScan._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setFieldValue(TTimeRange._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- setFileInfoOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setFileName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Get
-
Apply the specified server-side filter when performing the Get.
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Scan
-
Apply the specified server-side filter when performing the Scan.
- setFilter(String) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Set whether entire row should be filtered if column is not found.
- setFilterString(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setFilterString(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setFilterString(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setFilterString(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setFilterString(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setFilterString(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setFilterStringIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setFilterStringIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setFilterStringIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setFirst(T1) - Method in class org.apache.hadoop.hbase.util.Pair
-
Replace the first element of the pair.
- setFirstDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setFirstRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- setFirstRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
In HBase, the last row is represented by an empty byte array.
- setFirstRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- setFixAssignments(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Fix inconsistencies found by fsck.
- 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
-
- setFixTableOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixVersionFile(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- setFrags(Map<String, Integer>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setFrags(Map<String, Integer>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setFsDefault(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- setGeneralBloomFilterFaulty() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- setGenericException(ErrorHandlingProtos.GenericExceptionMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- setGenericException(ErrorHandlingProtos.GenericExceptionMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- setGet(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
the TGet to check for
- setGet(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
the TGet to fetch
- setGetIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- setGetIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- setGets(List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
a list of TGets to fetch, the Result list
will have the Results at corresponding positions
or null if there was an error
- setGetsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- setGroupPermissions(String, byte[], List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Overwrites the existing permission set for a group and triggers an update
for zookeeper synchronization.
- setHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- setHeaders(Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- setHeapSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- setHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- 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
-
- setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- 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.
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setIa(TIllegalArgument) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
if the scannerId is invalid
- setIa(TIllegalArgument) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
if the scannerId is invalid
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
This method allows you to set an identifier on an operation.
- setId(long) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setId(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- setId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
id of a scanner returned by scannerOpen
- setId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
id of a scanner returned by scannerOpen
- setId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
id of a scanner returned by scannerOpen
- setId(long) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- setIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- setIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- setIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setIgnorePreCheckPermission(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setIncrement(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
The single increment to apply
- setIncrement(TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
the TIncrement to increment
- setIncrementIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- setIncrementIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- setIncrements(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
The list of increments
- setIncrementsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- setInfoFamilyCachingForMeta(boolean) - Static method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Enable in memory caching for .META.
- setInfoFamilyCachingForRoot(boolean) - Static method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Enable in-memory caching for -ROOT-
- setInfoPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
-
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setInMemoryIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setInput(Job, String, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
Set job input.
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Deprecated.
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setIntHeader(String, int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- setIoException(IOException) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteResponse
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- setIsDelete(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setIsDeleteIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setIsMajor(boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Specify if this compaction should be a major compaction based on the state of the store
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setJerseyVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setJerseyVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- setJVMVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setJvmVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- setKeepDeletedCells(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setKey(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- setKey(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- setLastContact(long) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- setLastDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setLastRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- setLastRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
In HBase, the last row is represented by an empty byte array.
- setLastRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Set whether only the latest version of the column value should be compared.
- setLimit(int) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- setLimit(int) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- setLineNumber(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- setListener(EventHandler.EventHandlerListener) - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- setLiveNodes(List<StorageClusterStatusModel.Node>) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- setLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- 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).
- setLoadOnOpenOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setLocation(String) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setLocation(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- setLocations(Path, Path...) - Method in class org.apache.hadoop.hbase.io.FileLink
-
NOTE: This method must be used only in the constructor!
It creates a List with the specified locations for the link.
- setMapperClass(Job, Class<? extends Mapper<ImmutableBytesWritable, Result, K2, V2>>) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Set the application's mapper class.
- setMaster(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl.ImplData
-
- setMaster(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.DefaultLoadBalancer
-
- setMasterServices(MasterServices) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Set the master service.
- setMaxChunkSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- 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.
- setMaxHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setMaxHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- setMaxMemstoreTS(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- setMaxMerge(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setMaxOverlapsToSideline(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setMaxPoolSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- setMaxPoolSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- setMaxQueueSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- setMaxQueueSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- setMaxStamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- setMaxStampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- setMaxValues(int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- 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.client.UnmodifyableHColumnDescriptor
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setMaxVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setMaxVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setMaxVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- 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.
- setMemStoreSizeMB(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- setMemstoreSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setMemstoreSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setMemstoreTS(long) - Method in class org.apache.hadoop.hbase.KeyValue
-
- setMessage(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- setMetaIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setMetaLocation(ServerName) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setMetaLocation(ServerName) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setMetaRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used to denote if the current table represents
-ROOT-
or .META.
- setMethodName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- setMinStamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- setMinStampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- setMinVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setMutations(List<Mutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- setMutations(List<Mutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
list of mutation commands
- setMutations(List<Mutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
list of mutation commands
- setMutations(List<TMutation>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- setMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- setMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- setName(byte[]) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- setName(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Set the name of the table.
- setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- setName(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableModel
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- setName(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- setName(int, String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- setName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setName(String) - Method in class org.apache.hadoop.hbase.util.HasThread
-
- setNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setNbRows(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
number of results to return
- setNbRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- setNextPtr(LruHashMap.Entry<K, V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Sets the next pointer for the entry in the LRU.
- setNumberOfThreads(Job, int) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Set the number of threads in the pool for running maps.
- setNumDataIndexLevels(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setNumericMetric(String, long) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
- setNumericMetric(String, long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerDynamicMetrics
-
- setNumericPersistentMetric(String, long) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.RegionMetricsStorage
-
- 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.
- setNumRows(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
number of rows to return
- setNumRows(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
number of rows to return
- setNumRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- setNumRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- setNumVersions(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
number of versions to retrieve
- setNumVersions(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
number of versions to retrieve
- setNumVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setNumVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- 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.
- setOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Sets the region as offline by removing in-memory assignment information but
retaining transition information.
- setOffline(boolean) - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
The parent of a region split is offline while split daughters hold
references to the parent.
- setOperationStatus(int, OperationStatus) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Sets the status code for the operation(Mutation) at the specified position.
- setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
-
- setOpMetricsReadRequestCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setOpMetricsWriteRequestCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setOSVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setOsVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- setOwner(User) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setOwnerString(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setPartitionFile(Configuration, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.hadoopbackport.TotalOrderPartitioner
-
Set the path to the SequenceFile storing the sorted partition keyset.
- setPingInterval(Configuration, int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
set the ping interval value in configuration
- setPort(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setPortIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setPosition(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationHLogReaderManager
-
- setPrevPtr(LruHashMap.Entry<K, V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Sets the previous pointer for the entry in the LRU.
- setPriority(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Gets the priority for the request
- setPriority(int) - Method in class org.apache.hadoop.hbase.util.HasThread
-
- setPut(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
the TPut to put if the check succeeds
- setPut(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
the TPut to put
- setPut(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- setPutIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setPutIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- setPuts(List<TPut>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
a list of TPuts to commit
- setPutsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- setQosFunction(Function<Writable, Integer>) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Gets the QOS level for this call.
- setQosFunction(Function<Writable, Integer>) - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
column qualifier to check
- setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
column qualifier to check
- setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- 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.
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- setReadRequestCountMetrics(long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.OperationMetrics
-
- setReadRequestsCount(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- setReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setRegionCachePrefetch(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Enable or disable region cache prefetch for the table.
- setRegionCachePrefetch(byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Enable or disable region cache prefetch for the table.
- setRegionCachePrefetch(Configuration, byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Enable or disable region cache prefetch for the table.
- setRegionFilter(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
sets the region by which output will be filtered
- setRegionName(byte[]) - Method in class org.apache.hadoop.hbase.client.Action
-
Deprecated.
- setRegions(List<StorageClusterStatusModel.Node.Region>) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setRegions(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setRegions(List<TableRegionModel>) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- setRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- setRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- setRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- setRegions(int, TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- setRegions(int, TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- setRegionServer(HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setRegionServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
-
Set the list of region servers for that peer
- setRegionsToReopen(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Set the list of regions that will be reopened
because of an update in table schema
- setReplicating(boolean) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Kill switch for all replication-related features
- setReplicating(boolean) - Method in class org.apache.hadoop.hbase.replication.ReplicationZookeeper
-
Set the new replication state for this cluster
- setRequests(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setRequests(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setRequests(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- setRequests(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- setResponse(Object, Status, String, String) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- setResponse(Object, Status, String, String) - Method in class org.apache.hadoop.hbase.ipc.SecureServer.SecureCall
-
- setRESTVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setRestVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- setResult(R) - Method in class org.apache.hadoop.hbase.client.Action
-
- setRetCode(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setRetryCounts(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseFileSystem
-
- setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Append
-
- setRootDir(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- setRootIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setRootIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setRootLocation(ZooKeeperWatcher, ServerName) - Static method in class org.apache.hadoop.hbase.catalog.RootLocationEditor
-
Sets the location of -ROOT-
in ZooKeeper to the
specified server address.
- setRootLocation(ServerName) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setRootLocation(ServerName) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setRootRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used to denote if the current table represents
-ROOT-
region.
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
-
- setRow(byte[], int, short) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
Set current row
- setRow(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
row to increment
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Row to update
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
key of the row to be completely deleted.
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
key of the row to be completely deleted.
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Row to update
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
row to check
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
row to check
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- setRowBatches(List<BatchMutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
list of row batches
- setRowBatches(List<BatchMutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
list of row batches
- setRowBatchesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- setRowBatchesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- 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
-
- setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setRowFilter(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
sets the region by which output will be filtered
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- setRowMutations(TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
mutations to apply
- setRowMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- setRows(int, CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- setRows(int, CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- setRows(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
row keys
- setRows(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
row keys
- setRows(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
row keys
- setRows(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
row keys
- setRowsDeleted(long) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteResponse
-
- setRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- setRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- setRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- setRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setRPC(String, Object[], long) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- setRPC(String, Object[], long) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Tells this instance that it is monitoring a new RPC call.
- setRPCPacket(Writable) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- setRPCPacket(Writable) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Gives this instance a reference to the Writable received by the RPC, so
that it can later compute its size if asked for it.
- setRpcTimeout(int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseRPC
-
- 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.
- setScan(TScan) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Scan instance
- setScan(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
the scan object to get a Scanner for
- setScan(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
the scan object to get a Scanner for
- setScanIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- setScanIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- setScanIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- 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.
- setScannerId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
the Id of the Scanner to close *
- setScannerId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
the Id of the Scanner to return rows from.
- setScannerIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- setScannerIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- setScanQueryMatcher(ScanQueryMatcher) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- 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
-
- setScopes(NavigableMap<byte[], Integer>) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- setSecond(T2) - Method in class org.apache.hadoop.hbase.util.Pair
-
Replace the second element of the pair.
- setSecretManager(SecretManager<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.ipc.SecureServer
-
- setSelection(CompactSelection) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Set the files (and, implicitly, the size of the compaction based on those files)
- setSequenceFilter(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
sets the region by which output will be filtered
- setSequenceID(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- setSequenceNumber(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
Called by HRegionServer when it opens a new region to ensure that log
sequence numbers are always greater than the latest sequence number of the
region being brought on-line.
- setServer(HRegionServer) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- setServerManager(ServerManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setServerManager(ServerManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setServerName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setServerName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setServerNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setServerSideHConnectionRetries(Configuration, 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
.
- setServerVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setServerVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- setShowAppendWarning(boolean) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setShowAppendWarning(boolean) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setSidelineBigOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setSidelineDir(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setSkipChecks(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- setSmall(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether this scan is a small scan
- setSnapshotHandlerForTesting(String, SnapshotSentinel) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Set the handler for the current snapshot
- setSocketSendBufSize(int) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Sets the socket buffer size used for responding to RPCs.
- setSocketSendBufSize(int) - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
-
- setSocketTimeout(Configuration, int) - Static method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
Set the socket timeout
- setSortColumns(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setSortColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setSortedColumns(List<TColumn>) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setSortedColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setSource(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- setSplit(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- setSplit(boolean) - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- setStartAndPrefix(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
the prefix (and thus start row) of the keys you want
- setStartAndPrefix(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setStartAndPrefixIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setStartCode(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setStartCode(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- setStartKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- setStartKey(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setStartKey(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- setStartKey(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setStartKey(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setStartKeyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- 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
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setStartRow(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Starting row in table to scan.
- setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Starting row in table to scan.
- setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Starting row in table to scan.
- setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Starting row in table to scan.
- setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- setStatus(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- setStatus(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the stop row.
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
row to stop scanning on.
- setStopRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
row to stop scanning on.
- setStopRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setStopRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setStopRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setStopRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setStopRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setStopRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setStopRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setStorefiles(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- setStorefiles(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setStorefiles(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setStorefileSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setStorefileSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setStores(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- setStores(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setStores(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setSuccess(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- setSuccess(Map<ByteBuffer, ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- setSuccess(TRegionInfo) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- setSuccess(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- setSuccess(List<TRegionInfo>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- setSuccess(List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- setSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- setSuccess(List<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- setSuccess(List<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- setSuccess(List<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- setSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- setTable(String) - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- setTable(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
to check in and delete from
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
to check in and put to
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
the table to delete from
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
the table to delete from
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
the table to check on
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
the table to get from
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
the table to get from
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
the table to get the Scanner for
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
the table to increment the value on
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
table to apply the mutations
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
the table to get the Scanner for
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
the table to put data in
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
the table to put data in
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- setTableDesc(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
Do not use; expensive call
- setTableDesc(HTableDescriptor) - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- setTableInfo(HBaseFsck.TableInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Set the TableInfo used by all HRegionInfos fabricated by other callbacks
- setTableInfo(HBaseFsck.TableInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Set the TableInfo used by all HRegionInfos fabricated by other callbacks
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
name of table to create
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
name of table to delete
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
name of the table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
name of the table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
table name
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
name of the table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
name of the table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
table name
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
name of the table to check
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setTableNameOrRegionName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- setTableNameOrRegionName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- setTableNameOrRegionName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- setTableNameOrRegionName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- setTableNameOrRegionNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- setTableNameOrRegionNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- 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
-
- setTables(List<TableModel>) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- setTaskMonitor(TaskMonitor) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- setTaskMonitor(TaskMonitor) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- setThreadReadPoint(long) - Static method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Set the thread read point to the given value.
- 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
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).
- setTimeRange(TTimeRange) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setTimeRange(TTimeRange) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setTimeRangeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setTimeRangeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setTimeRangeTracker(TimeRangeTracker) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
Set TimeRangeTracker
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Set the timestamp of the delete.
- setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Get
-
Get versions of columns with the specified timestamp.
- setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get versions of columns with the specified timestamp.
- setTimestamp(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setTimeToLive(int) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
-
- setTimeToLive(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setTimeToLive(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setTimeToLiveIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setTotalCompactingKVs(long) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- setTotalCompactingKVs(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setTotalCompactingKVs(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setTotalStaticBloomSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setTotalStaticBloomSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setTotalStaticIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setTotalStaticIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setTotalUncompressedBytes(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setTrace(int, ErrorHandlingProtos.StackTraceElementMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- setTrace(int, ErrorHandlingProtos.StackTraceElementMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- setTtl(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- setType(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
-
- setType(HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.hadoop.hbase.util.HasThread
-
- setUncompressedDataIndexSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- 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).
- setupConnection() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- setupIOstreams() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
Connect to the server and set up the I/O streams.
- setupIOstreams() - Method in class org.apache.hadoop.hbase.ipc.SecureClient.SecureConnection
-
- setupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- setUserPermissions(String, byte[], List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Overwrites the existing permission set for a given user for a table, and
triggers an update for zookeeper synchronization.
- setUserProviderForTesting(Configuration, Class<? extends UserProvider>) - Static method in class org.apache.hadoop.hbase.client.UserProvider
-
Set the
UserProvider
in the given configuration that should be instantiated
- setUseTableNameInTest(boolean) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
Set the flag to use or not use table name in metric names.
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHColumnDescriptor
-
- 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
-
- setValue(Writable) - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Call
-
Set the return value when there is no error.
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.SplitKeyValue
-
- setValue(V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Set the value of this entry.
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- setValue(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- setValue(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- setValue(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
amount to increment by
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
the expected value, if not provided the
check is for the non-existence of the
column in question
- setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
the expected value, if not provided the
check is for the non-existence of the
column in question
- setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setValue(long) - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setValues(int, CellMessage.Cell) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- setValues(int, CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- setVersion(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- setVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
- setVersion(byte) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets version of file system
- setVersion(FileSystem, Path, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets version of file system
- setVersion(FileSystem, Path, String, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets version of file system
- setVersionIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setVersionsDeleted(long) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteResponse
-
- setWalEdit(int, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Sets the walEdit for the operation(Mutation) at the specified position.
- 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
-
- setWriteRequestCountMetrics(long) - Method in class org.apache.hadoop.hbase.regionserver.metrics.OperationMetrics
-
- setWriteRequestsCount(int) - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- setWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Increment
-
Sets whether this operation should write to the WAL or not.
- setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setWriteToWal(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setWriteToWal(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setWriteToWal(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setWriteToWALIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setWriteToWalIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setWriteToWalIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setWriteToWalIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- SEVENTY_FIFTH_PERCENTILE_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.KeyValue
-
Creates a shallow copy of this KeyValue, reusing the data byte buffer.
- shipEdits(boolean, List<HLog.Entry>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Do the shipping logic
- shippedBatchesRate - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceMetrics
-
Rate of shipped batches by the source
- shippedKBRate - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceMetrics
-
Rate of shipped bytes (in KB) by the source
- shippedOpsRate - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceMetrics
-
Rate of shipped operations by the source
- shouldBypass() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
For use by the coprocessor framework.
- shouldCacheBlockOnRead(BlockType.BlockCategory) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Should we cache a block of a particular category? We always cache
important blocks such as index blocks, as long as the block cache is
available.
- shouldCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCacheCompressed() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCacheDataOnRead() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns whether the blocks of this HFile should be cached on read or not.
- shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCloseConnection - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- shouldComplete() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
For use by the coprocessor framework.
- shouldEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldEvictOnClose() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldFixVersionFile() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- shouldIgnorePreCheckPermission() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- shouldRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- shouldSeek(Scan, long) - Method in class org.apache.hadoop.hbase.regionserver.MemStore
-
Check if this memstore may contain the required keys
- shouldSidelineBigOverlaps() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
-
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- shouldSplitHlog - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- shouldSplitMetaSeparately() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- shouldSplitMetaSeparately() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- shouldUseScanner(Scan, SortedSet<byte[]>, long) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Allows to filter out scanners (both StoreFile and memstore) that we don't
want to use based on criteria such as Bloom filters and timestamp ranges.
- shouldUseScanner(Scan, SortedSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.MemStore.MemStoreScanner
-
- shouldUseScanner(Scan, SortedSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- shouldUseScanner(Scan, SortedSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- shouldWriteBlock(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Whether there is an inline block ready to be written.
- shouldWriteBlock(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
Determines whether there is a new block to be written out.
- shouldWriteBlock(boolean) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- showAppendWarning - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- shutdown() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Shuts down the HBase cluster
- shutdown() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Clean up the environment
- shutdown(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- shutdown() - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- shutdown() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Shutdown the cache.
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
Sends a shutdown to all SingleSizeCache's contained by this cache.
- shutdown() - Method in class org.apache.hadoop.hbase.ipc.HBaseRpcMetrics
-
- shutdown() - Method in class org.apache.hadoop.hbase.ipc.HBaseRPCStatistics
-
- shutdown() - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Shutdown an 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.master.AssignmentManager
-
Shutdown the threadpool executor service
- shutdown() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- shutdown() - Method in class org.apache.hadoop.hbase.master.metrics.MasterMetrics
-
- shutdown() - Method in class org.apache.hadoop.hbase.master.metrics.MasterStatistics
-
- shutdown() - Method in class org.apache.hadoop.hbase.metrics.HBaseInfo.HBaseInfoMBean
-
- shutdown() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerDynamicMetrics
-
- shutdown() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerDynamicStatistics
-
- shutdown() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- shutdown() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerStatistics
-
- shutdown() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Shut down the client.
- shutdown() - Method in class org.apache.hadoop.hbase.rest.metrics.RESTMetrics
-
- shutdown() - Method in class org.apache.hadoop.hbase.rest.metrics.RESTStatistics
-
- shutdown() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
-
- shutdown(List<JVMClusterUtil.MasterThread>, List<JVMClusterUtil.RegionServerThread>) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
- shutdown() - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
Closes catalog regions if open.
- shutdown(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Shutdown passed thread using isAlive and join.
- shutdown(Thread, long) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Shutdown passed thread using isAlive and join.
- shutdown() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- shutdownCluster() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- ShutdownHook - Class in org.apache.hadoop.hbase.regionserver
-
Manage regionserver shutdown hooks.
- ShutdownHook() - Constructor for class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
- ShutdownHookManager - Class in org.apache.hadoop.hbase.util
-
This class provides ShutdownHookManager shims for HBase to interact with the Hadoop 1.0.x and the
Hadoop 2.0+ series.
- ShutdownHookManager() - Constructor for class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- SimpleBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
Simple one RFile soft reference cache.
- SimpleBlockCache() - Constructor for class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
Constructor
- 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() - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Writable constructor, do not use.
- 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, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter cells based on value.
- SingleColumnValueFilter() - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Writable constructor, do not use.
- 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, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for binary compare of the value of a single column.
- SingleSizeCache - Class in org.apache.hadoop.hbase.io.hfile.slab
-
SingleSizeCache is a slab allocated cache that caches elements up to a single
size.
- SingleSizeCache(int, int, SlabItemActionWatcher) - Constructor for class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
Default constructor.
- size() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
Get the total number of Actions
- size() - Method in class org.apache.hadoop.hbase.client.MultiPut
-
Deprecated.
- size() - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- size() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- size() - Method in class org.apache.hadoop.hbase.client.Result
-
- size() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- size() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the total size of the block cache, in bytes.
- size() - Method in class org.apache.hadoop.hbase.io.hfile.DoubleBlockCache
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the size of this cache (number of cached blocks)
- size() - Method in class org.apache.hadoop.hbase.io.hfile.SimpleBlockCache
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SingleSizeCache
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
- size - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.ParallelResults
-
- size - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- size() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Gets the size (number of entries) of the map.
- size() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- size() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- size() - Method in class org.apache.hadoop.hbase.util.ByteBufferOutputStream
-
- size() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- size() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- size(K) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- size() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- size() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- SizeBasedThrottler - Class in org.apache.hadoop.hbase.util
-
Utility class that can be used to implement
queues with limited capacity (in terms of memory).
- SizeBasedThrottler(long) - Constructor for class org.apache.hadoop.hbase.util.SizeBasedThrottler
-
Creates SizeBoundary with provided threshold
- 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
- sizeOfLogQueue - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceMetrics
-
Current size of the queue of logs to replicate,
excluding the one being processed at the moment
- skip(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Increment position in buffer.
- SKIP_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
SKIP Array
- SKIP_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- SkipFilter - Class in org.apache.hadoop.hbase.filter
-
A wrapper filter that filters an entire row if any of the KeyValue checks do
not pass.
- SkipFilter() - Constructor for class org.apache.hadoop.hbase.filter.SkipFilter
-
- SkipFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.SkipFilter
-
- skipKVsNewerThanReadpoint() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- skipSleepCycle() - Method in class org.apache.hadoop.hbase.util.Sleeper
-
If currently asleep, stops sleeping; if not asleep, will skip the next
sleep cycle.
- sl - Static variable in interface org.apache.hadoop.hbase.io.CodeToClassAndBack
-
The static loader that is used instead of the static constructor in
HbaseMapWritable.
- SlabCache - Class in org.apache.hadoop.hbase.io.hfile.slab
-
SlabCache is composed of multiple SingleSizeCaches.
- SlabCache(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.slab.SlabCache
-
Default constructor, creates an empty SlabCache.
- sleep() - Method in class org.apache.hadoop.hbase.Chore
-
Sleep for period.
- sleep() - Method in class org.apache.hadoop.hbase.util.Sleeper
-
Sleep for period.
- sleep(long) - Method in class org.apache.hadoop.hbase.util.Sleeper
-
Sleep for period adjusted by passed startTime
- sleep(long) - Static method in class org.apache.hadoop.hbase.util.Threads
-
- sleepBeforeRetry(String, int) - Static method in class org.apache.hadoop.hbase.HBaseFileSystem
-
sleeping logic for static methods; handles the interrupt exception.
- Sleeper - Class in org.apache.hadoop.hbase.util
-
Sleeper for current thread.
- Sleeper(int, Stoppable) - Constructor for class org.apache.hadoop.hbase.util.Sleeper
-
- sleepForRetries(String, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Do the sleeping logic
- sleepUntilNextRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
Sleep for a exponentially back off time
- sleepWithoutInterrupt(long) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Sleeps for the given amount of time even if interrupted.
- SLOW_RESPONSE_NANO_SEC - Static variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- slowHLogAppendCount - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- slowHLogAppendTime - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- snapshot(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a timestamp consistent snapshot for the given table.
- snapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Take a snapshot for the given table.
- snapshot(String, String, HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create typed snapshot of the table.
- 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(HSnapshotDescription) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
- snapshot(HSnapshotDescription) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Triggers an asynchronous attempt to take a snapshot.
- snapshot - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- snapshot - Variable in class org.apache.hadoop.hbase.snapshot.SnapshotTask
-
- SNAPSHOT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Name of the directory to store all snapshots.
- snapshot_jsp - Class in org.apache.hadoop.hbase.generated.master
-
- snapshot_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.snapshot_jsp
-
- SNAPSHOT_LAYOUT_VERSION - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Version of the fs layout for a snapshot.
- SNAPSHOT_REQUEST_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
# of threads for snapshotting regions on the rs.
- SNAPSHOT_REQUEST_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Conf key for number of request threads to start snapshots on regionservers
- SNAPSHOT_REQUEST_WAKE_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Conf key for millis between checks to see if snapshot completed or if there are errors
- SNAPSHOT_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Keep threads alive in request pool for max of 60 seconds
- SNAPSHOT_TIMEOUT_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Conf key for max time to keep threads in snapshot request pool waiting
- SNAPSHOT_TMP_DIR_NAME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Temporary directory under the snapshot directory to store in-progress 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
- SnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
-
- SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter - Class in org.apache.hadoop.hbase.snapshot
-
Filter that only accepts completed snapshot directories
- SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter
-
- snapshotDisabledRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Take a snapshot of the specified disabled region
- 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
- snapshotFailure(String, Exception) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTask
-
- SnapshotFileCache - Class in org.apache.hadoop.hbase.master.snapshot
-
Intelligently keep track of all the files for all the snapshots.
- SnapshotFileCache(Configuration, long, String, SnapshotFileCache.SnapshotFileInspector) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
Create a snapshot file cache for all snapshots under the specified [root]/.snapshot on the
filesystem.
- SnapshotFileCache(FileSystem, Path, long, long, String, SnapshotFileCache.SnapshotFileInspector) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
Create a snapshot file cache for all snapshots under the specified [root]/.snapshot on the
filesystem
- SnapshotFileCache.RefreshCacheTask - Class in org.apache.hadoop.hbase.master.snapshot
-
Simple helper task that just periodically attempts to refresh the cache
- SnapshotFileCache.RefreshCacheTask() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache.RefreshCacheTask
-
- SnapshotHFileCleaner - Class in org.apache.hadoop.hbase.master.snapshot
-
Implementation of a file cleaner that checks if a hfile is still used by snapshots of HBase
tables.
- SnapshotHFileCleaner() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- SnapshotInfo - Class in org.apache.hadoop.hbase.snapshot
-
Tool for dumping snapshot information.
- SnapshotInfo() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- SnapshotInfo.SnapshotStats - Class in org.apache.hadoop.hbase.snapshot
-
Statistics about the snapshot
How many store files and logs are in the archive
How many store files and logs are shared with the table
Total store files and logs size and shared amount
- SNAPSHOTINFO_FILE - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
The file contains the snapshot basic information and it is under the directory of a snapshot.
- SnapshotLogCleaner - Class in org.apache.hadoop.hbase.master.snapshot
-
Implementation of a log cleaner that checks if a log is still used by
snapshots of HBase tables.
- SnapshotLogCleaner() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
- SnapshotManager - Class in org.apache.hadoop.hbase.master.snapshot
-
This class manages the procedure of taking and restoring snapshots.
- SnapshotManager(MasterServices, MasterMetrics) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Construct a snapshot manager.
- SnapshotManager(MasterServices, MasterMetrics, ProcedureCoordinator, ExecutorService) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Fully specify all necessary components of a snapshot manager.
- SnapshotReferenceUtil - Class in org.apache.hadoop.hbase.snapshot
-
Utility methods for interacting with the snapshot referenced files.
- SnapshotReferenceUtil.FileVisitor - Interface in org.apache.hadoop.hbase.snapshot
-
- snapshotRegions(List<Pair<HRegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.DisabledTableSnapshotHandler
-
- snapshotRegions(List<Pair<HRegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.EnabledTableSnapshotHandler
-
This method kicks off a snapshot procedure.
- snapshotRegions(List<Pair<HRegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Snapshot the specified regions
- SnapshotSentinel - Interface in org.apache.hadoop.hbase.master
-
Watch the current snapshot under process
- SnapshotTask - Class in org.apache.hadoop.hbase.snapshot
-
General snapshot operation taken on a regionserver
- SnapshotTask(HBaseProtos.SnapshotDescription, ForeignExceptionDispatcher) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotTask
-
- socket - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
- socket - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- 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)
- socketFactory - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- socketSendBufferSize - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- socketTimeout - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- SoftValueSortedMap<K,V> - Class in org.apache.hadoop.hbase.util
-
A SortedMap implementation that uses Soft Reference values
internally to make it play well with the GC when in a low-memory
situation.
- SoftValueSortedMap() - Constructor for class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
Constructor
- SoftValueSortedMap(Comparator<K>) - Constructor for class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
Constructor
- sortAndClone(List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- sortColumns - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- sortedColumns - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- SortedCopyOnWriteSet<E> - Class in org.apache.hadoop.hbase.util
-
Simple
SortedSet
implementation that uses an internal
TreeSet
to provide ordering.
- SortedCopyOnWriteSet() - Constructor for class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- SortedCopyOnWriteSet(Collection<? extends E>) - Constructor for class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- SortedCopyOnWriteSet(Comparator<? super E>) - Constructor for class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- sortedPrefixes - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- SOURCE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- split(ByteBuffer) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- split(ByteBuffer, Callback<Void>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- split(ByteBuffer) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- 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() - Method in class org.apache.hadoop.hbase.KeyValue
-
- 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(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- split(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Split a pre-existing region into 2 regions.
- split(int) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Split an entire table.
- split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- split2(BigInteger, BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Divide 2 numbers in half (for split algorithm)
- 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
-
- SPLIT_SKIP_ERRORS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- SPLITA_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The lower-half split region column qualifier
- splitAllLogs(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- splitAllLogs(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- SPLITB_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The upper-half split region column qualifier
- splitKerberosName(String) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
Splitting fully qualified Kerberos name into parts
- splitkey - Variable in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- splitLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- splitLog(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- splitLog(List<ServerName>, PathFilter) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
This method is the base split method that splits HLog files matching a filter.
- splitLog() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
Split up a bunch of regionserver commit log files that are no longer being
written to, into new files, one per region for region to replay on startup.
- splitLog(CountDownLatch) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
Split up a bunch of regionserver commit log files that are no longer being
written to, into new files, one per region for region to replay on startup.
- splitLogDistributed(Path) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- splitLogDistributed(List<Path>) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
The caller will block until all the log files of the given region server
have been processed - successfully split or an error is encountered - by an
available worker region server.
- splitLogDistributed(List<Path>, PathFilter) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
The caller will block until all the META log files of the given region server
have been processed - successfully split or an error is encountered - by an
available worker region server.
- splitLogFile(Path, FileStatus, FileSystem, Configuration, CancelableProgressable) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
Splits a HLog file into region's recovered-edits directory
- splitLogFile(FileStatus, CancelableProgressable) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- SplitLogManager - Class in org.apache.hadoop.hbase.master
-
Distributes the task of log splitting to the available region servers.
- SplitLogManager(ZooKeeperWatcher, Configuration, Stoppable, MasterServices, String) - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager
-
Wrapper around #SplitLogManager(ZooKeeperWatcher, Configuration,
Stoppable, String, TaskFinisher)
that provides a task finisher for
copying recovered edits to their final destination.
- SplitLogManager(ZooKeeperWatcher, Configuration, Stoppable, MasterServices, String, SplitLogManager.TaskFinisher) - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager
-
Its OK to construct this object even when region-servers are not online.
- SplitLogManager.TaskFinisher - Interface in org.apache.hadoop.hbase.master
-
- SplitLogManager.TaskFinisher.Status - Enum in org.apache.hadoop.hbase.master
-
status that can be returned finish()
- SplitLogWorker - Class in org.apache.hadoop.hbase.regionserver
-
This worker is spawned in every regionserver (should we also spawn one in
the master?).
- SplitLogWorker(ZooKeeperWatcher, Configuration, String, SplitLogWorker.TaskExecutor) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
- SplitLogWorker(ZooKeeperWatcher, Configuration, String) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
- SplitLogWorker.TaskExecutor - Interface in org.apache.hadoop.hbase.regionserver
-
Objects implementing this interface actually do the task that has been
acquired by a
SplitLogWorker
.
- SplitLogWorker.TaskExecutor.Status - Enum in org.apache.hadoop.hbase.regionserver
-
- splitLogZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- splitMetaLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Specialized method to handle the splitting for meta HLog
- splitRegion(HRegionInfo) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Splits the specified region.
- splitRegion(HRegionInfo, byte[]) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
Splits the specified region.
- splitRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- splitRegion(HRegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- SplitRegionHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handles SPLIT region event on Master.
- SplitRegionHandler(Server, AssignmentManager, HRegionInfo, ServerName, List<HRegionInfo>) - Constructor for class org.apache.hadoop.hbase.master.handler.SplitRegionHandler
-
- splitStoreFile(LoadIncrementalHFiles.LoadQueueItem, HTable, byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- SPLITTING_EXT - Static variable in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
File Extension used while splitting an HLog into regions (HBASE-2312)
- SplitTransaction - Class in org.apache.hadoop.hbase.regionserver
-
Executes region split as a "transaction".
- SplitTransaction(HRegion, byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransaction
-
Constructor
- srcDir - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- stampSet - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- standardSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- start() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Starts the catalog tracker.
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseEndpointCoprocessor
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- start(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
-
- start() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
Start a timer to fail a process if it takes longer than the expected time to complete.
- start() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Starts the service.
- start() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
-
- START - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
Deprecated.
- start(ProcedureCoordinator) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Initialize and start threads necessary to connect an implementation's rpc mechanisms.
- start(String, ProcedureMember) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Initialize and start any threads or connections the member needs.
- start(ProcedureCoordinator) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
Start monitoring znodes in ZK - subclass hook to start monitoring znodes they are about.
- start(String, ProcedureMember) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- start() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Start accepting snapshot requests.
- start() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
start the SplitLogWorker thread
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- start() - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
- start() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- start() - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- start() - Method in class org.apache.hadoop.hbase.util.HasThread
-
- start() - Method in class org.apache.hadoop.hbase.zookeeper.DrainingServerTracker
-
Starts the tracking of draining RegionServers.
- start() - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
-
Starts the tracking of online RegionServers.
- start() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
- start() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Starts the tracking of the node in ZooKeeper.
- START_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
- startAndPrefix - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
the prefix (and thus start row) of the keys you want
- startCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
By acquiring a log sequence ID, we can allow log messages to continue while
we flush the cache.
- startCatalogJanitorChore() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Useful for testing purpose also where we have
master restart scenarios.
- startCode - Variable in class org.apache.hadoop.hbase.avro.generated.AServerInfo
-
- STARTCODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- STARTCODE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The startcode column qualifier
- startDelay(boolean) - Method in interface org.apache.hadoop.hbase.ipc.Delayable
-
Signal that the call response should be delayed, thus freeing the RPC
server to handle different requests.
- startDelay(boolean) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- startExecutorService(ExecutorService.ExecutorType, int) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- startKey - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- STARTKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- startMonitoring() - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
-
- startProcedure(ForeignExceptionDispatcher, String, byte[], List<String>) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Kick off the named procedure
- startRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This method needs to be called before any public call that reads or
modifies data.
- startRegionServer(HRegionServer) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- startRegionServer(HRegionServer, String) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- startReplicationService() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Start replication services.
- startReplicationService() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
If replication is enabled and this cluster is a master,
it starts
- startRow - Variable in class org.apache.hadoop.hbase.avro.generated.AScan
-
- startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Starting row in table to scan.
- startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Starting row in table to scan.
- startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Starting row in table to scan.
- startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Starting row in table to scan.
- startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- startRow - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- STARTROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- startStateTracker(ZooKeeperWatcher, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeer
-
start a state tracker to check whether this peer is enabled or not
- 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.
- startThreads() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Starts the service threads but does not allow requests to be responded yet.
- startThreads() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
-
- startThreads() - Method in class org.apache.hadoop.hbase.ipc.SecureRpcEngine.Server
-
- startTime - Variable in class org.apache.hadoop.hbase.client.ServerCallable
-
- STARTTIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- startup() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Initialize the environment
- startup() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Start the cluster.
- startup() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- startup() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Start the replication
- startup(List<JVMClusterUtil.MasterThread>, List<JVMClusterUtil.RegionServerThread>) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
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
-
- startWriting(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Starts writing into the block.
- state - Variable in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslStatus
-
- StateDumpServlet - Class in org.apache.hadoop.hbase.monitoring
-
- StateDumpServlet() - Constructor for class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- STATS_RECORD_SEP - Static variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Record separator for the Bloom filter statistics human-readable string
- status - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- std(byte[], ColumnInterpreter<R, S>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
This is the client side interface/handle for calling the std method for a
given cf-cq combination.
- STD_DEV_METRIC_NAME - Static variable in class org.apache.hadoop.hbase.metrics.histogram.MetricsHistogram
-
- stepDownAsLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Removes the leader znode, if it is currently claimed by this instance.
- stop() - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Stop working.
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseEndpointCoprocessor
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- stop(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient
-
Stop all threads related to this client.
- stop() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer
-
Stops the service.
- stop(String) - Method in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
- stop() - Method in interface org.apache.hadoop.hbase.ipc.RpcServer
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.SecureServer
-
Stops the service.
- stop() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- stop() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- stop() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- stop() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Stop the ServerManager.
- stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- stop() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- stop(boolean) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Close this and all running snapshot tasks
- stop() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
stop the SplitLogWorker thread
- stop(String) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- stop() - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- stop() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- stop(String) - Method in interface org.apache.hadoop.hbase.Stoppable
-
Stop this service.
- stop() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- stop() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- stop() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
- STOP_TIMEOUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Time to wait for server to stop gracefully
- stopMaster() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Shuts down the current HBase master only.
- stopMaster() - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Stop HBase Master only.
- stopMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- stopMonitoring() - Method in class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
-
- Stoppable - Interface in org.apache.hadoop.hbase
-
Implementers are Stoppable.
- stopped - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- stopper - Variable in class org.apache.hadoop.hbase.Chore
-
- stopRegionServer(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Stop the designated regionserver
- stopReplicationService() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Stops replication service.
- stopReplicationService() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Stops replication service.
- stopReplicationSinkServices() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
stop the thread pool executor.
- stopReportMetrics() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceMetrics
-
- stopRow - Variable in class org.apache.hadoop.hbase.avro.generated.AScan
-
- stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
row to stop scanning on.
- stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
row to stop scanning on.
- stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- stopRow - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- StorageClusterStatusMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusMessage.StorageClusterStatus - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusMessage.StorageClusterStatus.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusMessage.StorageClusterStatus.Node - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusMessage.StorageClusterStatus.Node.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusMessage.StorageClusterStatus.Region - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusMessage.StorageClusterStatus.Region.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusMessage.StorageClusterStatusOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of the status of a storage cluster:
- StorageClusterStatusModel() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Default constructor
- StorageClusterStatusModel.Node - Class in org.apache.hadoop.hbase.rest.model
-
Represents a region server.
- StorageClusterStatusModel.Node() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Default constructor
- StorageClusterStatusModel.Node(String, long) - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Constructor
- StorageClusterStatusModel.Node.Region - Class in org.apache.hadoop.hbase.rest.model
-
Represents a region hosted on a region server.
- StorageClusterStatusModel.Node.Region() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Default constructor
- StorageClusterStatusModel.Node.Region(byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Constructor
- StorageClusterStatusModel.Node.Region(byte[], int, int, int, int, int, long, long, int, int, int, long, long) - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Constructor
- StorageClusterStatusResource - Class in org.apache.hadoop.hbase.rest
-
- StorageClusterStatusResource() - Constructor for class org.apache.hadoop.hbase.rest.StorageClusterStatusResource
-
Constructor
- StorageClusterVersionModel - Class in org.apache.hadoop.hbase.rest.model
-
Simple representation of the version of the storage cluster
- StorageClusterVersionModel() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
- StorageClusterVersionResource - Class in org.apache.hadoop.hbase.rest
-
- StorageClusterVersionResource() - Constructor for class org.apache.hadoop.hbase.rest.StorageClusterVersionResource
-
Constructor
- Store - Class in org.apache.hadoop.hbase.regionserver
-
A Store holds a column family in a Region.
- Store(Path, HRegion, HColumnDescriptor, FileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.Store
-
Constructor
- Store.ScanInfo - Class in org.apache.hadoop.hbase.regionserver
-
Immutable information for scans over a store.
- Store.ScanInfo(HColumnDescriptor, long, long, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.Store.ScanInfo
-
- Store.ScanInfo(byte[], int, int, long, boolean, long, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.Store.ScanInfo
-
- StoreFile - Class in org.apache.hadoop.hbase.regionserver
-
A Store data file.
- StoreFile(FileSystem, Path, Configuration, CacheConfig, StoreFile.BloomType, HFileDataBlockEncoder) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile
-
Constructor, loads a reader and it's indices, etc.
- storeFile(String, String, String) - Method in interface org.apache.hadoop.hbase.util.FSVisitor.StoreFileVisitor
-
- StoreFile.BloomType - Enum in org.apache.hadoop.hbase.regionserver
-
- StoreFile.Reader - Class in org.apache.hadoop.hbase.regionserver
-
Reader for a StoreFile.
- StoreFile.Reader(FileSystem, Path, CacheConfig, DataBlockEncoding) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- StoreFile.Reader(FileSystem, Path, HFileLink, long, CacheConfig, DataBlockEncoding, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- StoreFile.Writer - Class in org.apache.hadoop.hbase.regionserver
-
A StoreFile writer.
- StoreFile.WriterBuilder - Class in org.apache.hadoop.hbase.regionserver
-
- StoreFile.WriterBuilder(Configuration, CacheConfig, FileSystem, int) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- storefileIndexSizeInMB - Variable in class org.apache.hadoop.hbase.avro.generated.AServerLoad
-
- storefileIndexSizeMB - Variable in class org.apache.hadoop.hbase.avro.generated.ARegionLoad
-
- storefileIndexSizeMB - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- STOREFILEINDEXSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- storefiles - Variable in class org.apache.hadoop.hbase.avro.generated.ARegionLoad
-
- storefiles - Variable in class org.apache.hadoop.hbase.avro.generated.AServerLoad
-
- storefiles - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
Count of storefiles open on the regionserver.
- STOREFILES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- StoreFileScanner - Class in org.apache.hadoop.hbase.regionserver
-
KeyValueScanner adaptor over the Reader.
- StoreFileScanner(StoreFile.Reader, HFileScanner, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- storefileSizeInMB - Variable in class org.apache.hadoop.hbase.avro.generated.AServerLoad
-
- storefileSizeMB - Variable in class org.apache.hadoop.hbase.avro.generated.ARegionLoad
-
- STOREFILESIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- stores - Variable in class org.apache.hadoop.hbase.avro.generated.ARegionLoad
-
- stores - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- stores - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
Count of stores open on the regionserver.
- STORES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- StoreScanner - Class in org.apache.hadoop.hbase.regionserver
-
Scanner scans both the memstore and the HStore.
- StoreScanner(Store, Store.ScanInfo, Scan, NavigableSet<byte[]>) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Opens a scanner across memstore, snapshot, and all StoreFiles.
- StoreScanner(Store, Store.ScanInfo, Scan, List<? extends KeyValueScanner>, ScanType, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Used for major compactions.
- STRING - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
String overhead
- stringify(Class[]) - Static method in class org.apache.hadoop.hbase.util.Classes
-
- stringifyFilter(Filter) - Static method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- Strings - Class in org.apache.hadoop.hbase.util
-
Utility for Strings.
- Strings() - Constructor for class org.apache.hadoop.hbase.util.Strings
-
- strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- strToRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
- strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- subList(int, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactSelection
-
- subMap(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- subMap(K, K) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- submit(EventHandler) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- submitSubprocedure(Subprocedure) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Submit an subprocedure for execution.
- Subprocedure - Class in org.apache.hadoop.hbase.procedure
-
Distributed procedure member's Subprocedure.
- Subprocedure(ProcedureMember, String, ForeignExceptionDispatcher, long, long) - Constructor for class org.apache.hadoop.hbase.procedure.Subprocedure
-
- Subprocedure.SubprocedureImpl - Class in org.apache.hadoop.hbase.procedure
-
Empty Subprocedure for testing.
- Subprocedure.SubprocedureImpl(ProcedureMember, String, ForeignExceptionDispatcher, long, long) - Constructor for class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- SubprocedureFactory - Interface in org.apache.hadoop.hbase.procedure
-
- subSet(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- subSet(KeyValue, boolean, KeyValue, boolean) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- subSet(E, E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- 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() - Constructor for class org.apache.hadoop.hbase.filter.SubstringComparator
-
Nullary constructor for Writable, do not use
- 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
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- sum(byte[], ColumnInterpreter<R, S>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
It sums up the value returned from various regions.
- summarize() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- sumOfMillisSecBetweenNexts - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
sum of milliseconds between sequential next calls
- SUPERUSER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Configuration key for superusers
- supportsAutoLoading() - Method in interface org.apache.hadoop.hbase.util.BloomFilter
-
- supportsAutoLoading() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- supportsAutoLoading() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- suspendEncoding() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
-
Suspends encoding of the stream.
- SWITCH_TO_SIMPLE_AUTH - Static variable in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- switchBalancer(boolean, HMaster.BalanceSwitchMode) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Assigns balancer switch according to BalanceSwitchMode
- sync() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- sync(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- sync() - Method in interface org.apache.hadoop.hbase.regionserver.wal.HLog.Writer
-
- sync() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
-
- sync(String, AsyncCallback.VoidCallback, Object) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- sync(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Forces a synchronization of this ZooKeeper client connection.
- synchronousBalanceSwitch(boolean) - Method in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
Turn the load balancer on or off.
- synchronousBalanceSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- TAB - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for tab
- table - Variable in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
to check in and delete from
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
to check in and put to
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
the table to delete from
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
the table to delete from
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
the table to check on
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
the table to get from
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
the table to get from
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
the table to get the Scanner for
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
the table to increment the value on
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
table to apply the mutations
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
the table to get the Scanner for
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
the table to put data in
- table - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
the table to put data in
- TABLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- table_jsp - Class in org.apache.hadoop.hbase.generated.master
-
- table_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.table_jsp
-
- TABLE_PREFIX - Static variable in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- TableAddFamilyHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handles adding a new family to an existing table.
- TableAddFamilyHandler(byte[], HColumnDescriptor, Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
-
- TableAuthManager - Class in org.apache.hadoop.hbase.security.access
-
Performs authorization checks for a given user's assigned permissions
- TableDeleteFamilyHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handles adding a new family to an existing table.
- TableDeleteFamilyHandler(byte[], byte[], Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
-
- tableDesc - Variable in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- TableDescriptors - Interface in org.apache.hadoop.hbase
-
Get, remove and modify table descriptors.
- TableEventHandler - Class in org.apache.hadoop.hbase.master.handler
-
Base class for performing operations against tables.
- TableEventHandler(EventHandler.EventType, byte[], Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- tableExists(ByteBuffer) - Method in class org.apache.hadoop.hbase.avro.AvroServer.HBaseImpl
-
- tableExists(ByteBuffer, Callback<Boolean>) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase.Callback
-
- tableExists(ByteBuffer) - Method in interface org.apache.hadoop.hbase.avro.generated.HBase
-
- tableExists(CatalogTracker, String) - Static method in class org.apache.hadoop.hbase.catalog.MetaReader
-
Checks if the specified table exists.
- tableExists(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- tableExists(byte[]) - 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
- tableHasErrors(HBaseFsck.TableInfo) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- TABLEINFO_NAME - Static variable in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
The file name used to store HTD in HDFS
- TableInfoCopyTask - Class in org.apache.hadoop.hbase.snapshot
-
Copy the table info into the snapshot directory
- TableInfoCopyTask(ForeignExceptionDispatcher, HBaseProtos.SnapshotDescription, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.snapshot.TableInfoCopyTask
-
Copy the table info for the given table into the snapshot
- TableInfoMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableInfoMessage.TableInfo - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableInfoMessage.TableInfo.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableInfoMessage.TableInfo.Region - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableInfoMessage.TableInfo.Region.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableInfoMessage.TableInfo.RegionOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableInfoMessage.TableInfoOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- 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
-
- TableInfoModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a list of table regions.
- TableInfoModel() - Constructor for class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
Default constructor
- TableInfoModel(String) - Constructor for class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
Constructor
- 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
-
- TableIntegrityErrorHandler - Interface in org.apache.hadoop.hbase.util.hbck
-
This interface provides callbacks for handling particular table integrity
invariant violations.
- TableIntegrityErrorHandlerImpl - Class in org.apache.hadoop.hbase.util.hbck
-
Simple implementation of TableIntegrityErrorHandler.
- TableIntegrityErrorHandlerImpl() - Constructor for class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
- TableListMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableListMessage.TableList - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableListMessage.TableList.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableListMessage.TableListOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableListModel - Class in org.apache.hadoop.hbase.rest.model
-
Simple representation of a list of table names.
- TableListModel() - Constructor for class org.apache.hadoop.hbase.rest.model.TableListModel
-
Default constructor
- TableMap<K extends org.apache.hadoop.io.WritableComparable<? super K>,V extends org.apache.hadoop.io.Writable> - 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
-
- TableModel - Class in org.apache.hadoop.hbase.rest.model
-
Simple representation of a table name.
- TableModel() - Constructor for class org.apache.hadoop.hbase.rest.model.TableModel
-
Default constructor
- TableModel(String) - Constructor for class org.apache.hadoop.hbase.rest.model.TableModel
-
Constructor
- TableModifyFamilyHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handles adding a new family to an existing table.
- TableModifyFamilyHandler(byte[], HColumnDescriptor, Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
-
- tableName - Variable in class org.apache.hadoop.hbase.client.ServerCallable
-
- tableName - Variable in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
name of table to create
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
name of table to delete
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
name of the table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
name of the table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
table name
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
name of the table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
name of the table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
table name
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
name of the table to check
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
name of table
- tableName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
name of table
- tableNameOrRegionName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- tableNameOrRegionName - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- tableNameStr - Variable in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- 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
-
- 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(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
-
- 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
-
- TableOutputFormat.TableRecordWriter - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
Convert Reduce output (key, value) to (HStoreKey, KeyedDataArrayWritable)
and write to an HBase table
- TableOutputFormat.TableRecordWriter(HTable) - Constructor for class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
-
Deprecated.
Instantiate a TableRecordWriter with the HBase HClient for writing.
- TableOutputFormat.TableRecordWriter<KEY> - Class in org.apache.hadoop.hbase.mapreduce
-
Writes the reducer output to an HBase table.
- TableOutputFormat.TableRecordWriter(HTable) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
-
Instantiate a TableRecordWriter with the HBase HClient for writing.
- 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(byte[]) - Constructor for exception org.apache.hadoop.hbase.snapshot.TablePartiallyOpenException
-
- TablePermission - Class in org.apache.hadoop.hbase.security.access
-
Represents an authorization for access for the given actions, optionally
restricted to the given column family or column qualifier, over the
given table.
- TablePermission() - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
-
Nullary constructor for Writable, do not use
- TablePermission(byte[], byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
-
Create a new permission for the given table and (optionally) column family,
allowing the given actions.
- TablePermission(byte[], byte[], byte[], Permission.Action...) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
-
Creates a new permission for the given table, restricted to the given
column family and qualifer, allowing the assigned actions to be performed.
- TablePermission(byte[], byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.TablePermission
-
Creates a new permission for the given table, family and column qualifier,
allowing the actions matching the provided byte codes to be performed.
- TableRecordReader - Class in org.apache.hadoop.hbase.mapred
-
Iterate over an HBase table data, return (Text, RowResult) pairs
- TableRecordReader() - Constructor for class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- 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
-
Iterate over an HBase table data, return (Text, RowResult) pairs
- TableRecordReaderImpl() - Constructor for class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- 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 extends org.apache.hadoop.io.Writable> - 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
-
- TableRegionModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a region of a table and its current location on the
storage cluster.
- TableRegionModel() - Constructor for class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
Constructor
- TableRegionModel(String, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
Constructor
- TableRegionModel(String, long, byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
Constructor
- TableResource - Class in org.apache.hadoop.hbase.rest
-
- TableResource(String) - Constructor for class org.apache.hadoop.hbase.rest.TableResource
-
Constructor
- TableSchemaMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableSchemaMessage.TableSchema - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableSchemaMessage.TableSchema.Attribute - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableSchemaMessage.TableSchema.Attribute.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableSchemaMessage.TableSchema.AttributeOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableSchemaMessage.TableSchema.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableSchemaMessage.TableSchemaOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- TableSchemaModel - Class in org.apache.hadoop.hbase.rest.model
-
A representation of HBase table descriptors.
- TableSchemaModel() - Constructor for class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Default constructor.
- TableSchemaModel(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Constructor
- tablesDetailed_jsp - Class in org.apache.hadoop.hbase.generated.master
-
- tablesDetailed_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.tablesDetailed_jsp
-
- 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
-
- TableSnapshotInputFormat.TableSnapshotRegionRecordReader - Class in org.apache.hadoop.hbase.mapreduce
-
Snapshot region record reader.
- TableSnapshotInputFormat.TableSnapshotRegionRecordReader() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionRecordReader
-
- TableSnapshotInputFormat.TableSnapshotRegionSplit - Class in org.apache.hadoop.hbase.mapreduce
-
Snapshot region split.
- TableSnapshotInputFormat.TableSnapshotRegionSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
Constructor for serialization.
- TableSnapshotInputFormat.TableSnapshotRegionSplit(String, List<String>) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
Constructor.
- TableSplit - Class in org.apache.hadoop.hbase.mapred
-
Deprecated.
- TableSplit() - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
default constructor
- TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapred.TableSplit
-
Deprecated.
Constructor
- 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
-
Creates a new instance while assigning all variables.
- TableSplit(byte[], byte[], byte[], String) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Creates a new instance without a scanner.
- tail(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- tailMap(byte[]) - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- tailMap(K) - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- tailSet(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- tailSet(KeyValue, boolean) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- tailSet(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- take() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- takeSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Take a snapshot based on the enabled/disabled state of the table.
- 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)
- TakeSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
-
A handler for taking snapshots from the master.
- TakeSnapshotHandler(HBaseProtos.SnapshotDescription, MasterServices, MasterMetrics) - Constructor for class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- TakeSnapshotUtils - Class in org.apache.hadoop.hbase.snapshot
-
Utilities for useful when taking a snapshot
- TaskMonitor - Class in org.apache.hadoop.hbase.monitoring
-
Singleton which keeps track of tasks going on in this VM.
- TaskMonitor() - Constructor for class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- taskMonitor - Variable in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- TaskMonitorTmpl - Class in org.apache.hadoop.hbase.tmpl.common
-
- TaskMonitorTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- TaskMonitorTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- TaskMonitorTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.common
-
- TaskMonitorTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- TaskMonitorTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.common
-
- TaskMonitorTmplImpl - Class in org.apache.hadoop.hbase.tmpl.common
-
- TaskMonitorTmplImpl(TemplateManager, TaskMonitorTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmplImpl
-
- TBoundedThreadPoolServer - Class in org.apache.hadoop.hbase.thrift
-
A bounded thread pool server customized for HBase.
- TBoundedThreadPoolServer(TBoundedThreadPoolServer.Args, ThriftMetrics) - Constructor for class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- TBoundedThreadPoolServer.Args - Class in org.apache.hadoop.hbase.thrift
-
- TBoundedThreadPoolServer.Args(TServerTransport, Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.Args
-
- TCell - Class in org.apache.hadoop.hbase.thrift.generated
-
TCell - Used to transport a cell value (byte[]) and the timestamp it was
stored with together as a result for get and getRow methods.
- TCell() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TCell
-
- TCell(ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TCell
-
- TCell(TCell) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TCell
-
Performs a deep copy on other.
- TCell._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TColumn - Class in org.apache.hadoop.hbase.thrift.generated
-
Holds column name and the cell.
- TColumn() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- TColumn(ByteBuffer, TCell) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- TColumn(TColumn) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TColumn
-
Performs a deep copy on other.
- TColumn - Class in org.apache.hadoop.hbase.thrift2.generated
-
Addresses a single cell or multiple cells
in a HBase table by column family and optionally
a column qualifier and timestamp
- TColumn() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- TColumn(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- TColumn(TColumn) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
Performs a deep copy on other.
- TColumn._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TColumn._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TColumnIncrement - Class in org.apache.hadoop.hbase.thrift2.generated
-
Represents a single cell and the amount to increment it by
- TColumnIncrement() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- TColumnIncrement(ByteBuffer, ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- TColumnIncrement(TColumnIncrement) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
Performs a deep copy on other.
- TColumnIncrement._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TColumnValue - Class in org.apache.hadoop.hbase.thrift2.generated
-
Represents a single cell and its value.
- TColumnValue() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- TColumnValue(ByteBuffer, ByteBuffer, ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- TColumnValue(TColumnValue) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
Performs a deep copy on other.
- TColumnValue._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- tcpKeepAlive - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- tcpNoDelay - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- TDelete - Class in org.apache.hadoop.hbase.thrift2.generated
-
Used to perform Delete operations on a single row.
- TDelete() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- TDelete(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- TDelete(TDelete) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
Performs a deep copy on other.
- TDelete._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TDeleteType - Enum in org.apache.hadoop.hbase.thrift2.generated
-
Specify type of delete:
- DELETE_COLUMN means exactly one version will be removed,
- DELETE_COLUMNS means previous versions will also be removed.
- TDurability - Enum in org.apache.hadoop.hbase.thrift2.generated
-
Specify Durability:
- SKIP_WAL means do not write the Mutation to the WAL.
- terminate(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- terminate(String, Exception) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- terminate(String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
End the replication
- terminate(String, Exception) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
End the replication
- TEST_SKIP - Static variable in class org.apache.hadoop.hbase.master.handler.SplitRegionHandler
-
For testing only! Set to true to skip handling of split.
- 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
-
- TGet - Class in org.apache.hadoop.hbase.thrift2.generated
-
Used to perform Get operations on a single row.
- TGet() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- TGet(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- TGet(TGet) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TGet
-
Performs a deep copy on other.
- TGet._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService
-
- THBaseService.AsyncClient - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- THBaseService.AsyncClient.checkAndDelete_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.checkAndDelete_call(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, AsyncMethodCallback<THBaseService.AsyncClient.checkAndDelete_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndDelete_call
-
- THBaseService.AsyncClient.checkAndPut_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.checkAndPut_call(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, AsyncMethodCallback<THBaseService.AsyncClient.checkAndPut_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndPut_call
-
- THBaseService.AsyncClient.closeScanner_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.closeScanner_call(int, AsyncMethodCallback<THBaseService.AsyncClient.closeScanner_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.closeScanner_call
-
- THBaseService.AsyncClient.deleteMultiple_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.deleteMultiple_call(ByteBuffer, List<TDelete>, AsyncMethodCallback<THBaseService.AsyncClient.deleteMultiple_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteMultiple_call
-
- THBaseService.AsyncClient.deleteSingle_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.deleteSingle_call(ByteBuffer, TDelete, AsyncMethodCallback<THBaseService.AsyncClient.deleteSingle_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteSingle_call
-
- THBaseService.AsyncClient.exists_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.exists_call(ByteBuffer, TGet, AsyncMethodCallback<THBaseService.AsyncClient.exists_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.exists_call
-
- THBaseService.AsyncClient.Factory - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.Factory
-
- THBaseService.AsyncClient.get_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.get_call(ByteBuffer, TGet, AsyncMethodCallback<THBaseService.AsyncClient.get_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.get_call
-
- THBaseService.AsyncClient.getMultiple_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.getMultiple_call(ByteBuffer, List<TGet>, AsyncMethodCallback<THBaseService.AsyncClient.getMultiple_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getMultiple_call
-
- THBaseService.AsyncClient.getScannerResults_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.getScannerResults_call(ByteBuffer, TScan, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerResults_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerResults_call
-
- THBaseService.AsyncClient.getScannerRows_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.getScannerRows_call(int, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerRows_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerRows_call
-
- THBaseService.AsyncClient.increment_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.increment_call(ByteBuffer, TIncrement, AsyncMethodCallback<THBaseService.AsyncClient.increment_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.increment_call
-
- THBaseService.AsyncClient.mutateRow_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.mutateRow_call(ByteBuffer, TRowMutations, AsyncMethodCallback<THBaseService.AsyncClient.mutateRow_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.mutateRow_call
-
- THBaseService.AsyncClient.openScanner_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.openScanner_call(ByteBuffer, TScan, AsyncMethodCallback<THBaseService.AsyncClient.openScanner_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.openScanner_call
-
- THBaseService.AsyncClient.put_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.put_call(ByteBuffer, TPut, AsyncMethodCallback<THBaseService.AsyncClient.put_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.put_call
-
- THBaseService.AsyncClient.putMultiple_call - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.AsyncClient.putMultiple_call(ByteBuffer, List<TPut>, AsyncMethodCallback<THBaseService.AsyncClient.putMultiple_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.putMultiple_call
-
- THBaseService.AsyncIface - Interface in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.checkAndDelete_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.checkAndDelete_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- THBaseService.checkAndDelete_args(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- THBaseService.checkAndDelete_args(THBaseService.checkAndDelete_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
Performs a deep copy on other.
- THBaseService.checkAndDelete_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.checkAndDelete_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.checkAndDelete_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- THBaseService.checkAndDelete_result(boolean, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- THBaseService.checkAndDelete_result(THBaseService.checkAndDelete_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
Performs a deep copy on other.
- THBaseService.checkAndDelete_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.checkAndPut_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.checkAndPut_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- THBaseService.checkAndPut_args(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- THBaseService.checkAndPut_args(THBaseService.checkAndPut_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
Performs a deep copy on other.
- THBaseService.checkAndPut_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.checkAndPut_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.checkAndPut_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- THBaseService.checkAndPut_result(boolean, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- THBaseService.checkAndPut_result(THBaseService.checkAndPut_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
Performs a deep copy on other.
- THBaseService.checkAndPut_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.Client - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.Client(TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- THBaseService.Client(TProtocol, TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- THBaseService.Client.Factory - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.Client.Factory() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client.Factory
-
- THBaseService.closeScanner_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.closeScanner_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- THBaseService.closeScanner_args(int) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- THBaseService.closeScanner_args(THBaseService.closeScanner_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
Performs a deep copy on other.
- THBaseService.closeScanner_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.closeScanner_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.closeScanner_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- THBaseService.closeScanner_result(TIOError, TIllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- THBaseService.closeScanner_result(THBaseService.closeScanner_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
Performs a deep copy on other.
- THBaseService.closeScanner_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.deleteMultiple_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.deleteMultiple_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- THBaseService.deleteMultiple_args(ByteBuffer, List<TDelete>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- THBaseService.deleteMultiple_args(THBaseService.deleteMultiple_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
Performs a deep copy on other.
- THBaseService.deleteMultiple_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.deleteMultiple_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.deleteMultiple_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- THBaseService.deleteMultiple_result(List<TDelete>, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- THBaseService.deleteMultiple_result(THBaseService.deleteMultiple_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
Performs a deep copy on other.
- THBaseService.deleteMultiple_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.deleteSingle_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.deleteSingle_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- THBaseService.deleteSingle_args(ByteBuffer, TDelete) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- THBaseService.deleteSingle_args(THBaseService.deleteSingle_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
Performs a deep copy on other.
- THBaseService.deleteSingle_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.deleteSingle_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.deleteSingle_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- THBaseService.deleteSingle_result(TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- THBaseService.deleteSingle_result(THBaseService.deleteSingle_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
Performs a deep copy on other.
- THBaseService.deleteSingle_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.exists_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.exists_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- THBaseService.exists_args(ByteBuffer, TGet) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- THBaseService.exists_args(THBaseService.exists_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
Performs a deep copy on other.
- THBaseService.exists_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.exists_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.exists_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- THBaseService.exists_result(boolean, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- THBaseService.exists_result(THBaseService.exists_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
Performs a deep copy on other.
- THBaseService.exists_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.get_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.get_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- THBaseService.get_args(ByteBuffer, TGet) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- THBaseService.get_args(THBaseService.get_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
Performs a deep copy on other.
- THBaseService.get_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.get_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.get_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- THBaseService.get_result(TResult, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- THBaseService.get_result(THBaseService.get_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
Performs a deep copy on other.
- THBaseService.get_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.getMultiple_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.getMultiple_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- THBaseService.getMultiple_args(ByteBuffer, List<TGet>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- THBaseService.getMultiple_args(THBaseService.getMultiple_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
Performs a deep copy on other.
- THBaseService.getMultiple_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.getMultiple_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.getMultiple_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- THBaseService.getMultiple_result(List<TResult>, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- THBaseService.getMultiple_result(THBaseService.getMultiple_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
Performs a deep copy on other.
- THBaseService.getMultiple_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.getScannerResults_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.getScannerResults_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- THBaseService.getScannerResults_args(ByteBuffer, TScan, int) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- THBaseService.getScannerResults_args(THBaseService.getScannerResults_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
Performs a deep copy on other.
- THBaseService.getScannerResults_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.getScannerResults_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.getScannerResults_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- THBaseService.getScannerResults_result(List<TResult>, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- THBaseService.getScannerResults_result(THBaseService.getScannerResults_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
Performs a deep copy on other.
- THBaseService.getScannerResults_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.getScannerRows_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.getScannerRows_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- THBaseService.getScannerRows_args(int, int) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- THBaseService.getScannerRows_args(THBaseService.getScannerRows_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
Performs a deep copy on other.
- THBaseService.getScannerRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.getScannerRows_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.getScannerRows_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- THBaseService.getScannerRows_result(List<TResult>, TIOError, TIllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- THBaseService.getScannerRows_result(THBaseService.getScannerRows_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
Performs a deep copy on other.
- THBaseService.getScannerRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.Iface - Interface in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.increment_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.increment_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- THBaseService.increment_args(ByteBuffer, TIncrement) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- THBaseService.increment_args(THBaseService.increment_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
Performs a deep copy on other.
- THBaseService.increment_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.increment_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.increment_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- THBaseService.increment_result(TResult, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- THBaseService.increment_result(THBaseService.increment_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
Performs a deep copy on other.
- THBaseService.increment_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.mutateRow_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.mutateRow_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- THBaseService.mutateRow_args(ByteBuffer, TRowMutations) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- THBaseService.mutateRow_args(THBaseService.mutateRow_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
Performs a deep copy on other.
- THBaseService.mutateRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.mutateRow_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.mutateRow_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- THBaseService.mutateRow_result(TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- THBaseService.mutateRow_result(THBaseService.mutateRow_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
Performs a deep copy on other.
- THBaseService.mutateRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.openScanner_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.openScanner_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- THBaseService.openScanner_args(ByteBuffer, TScan) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- THBaseService.openScanner_args(THBaseService.openScanner_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
Performs a deep copy on other.
- THBaseService.openScanner_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.openScanner_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.openScanner_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- THBaseService.openScanner_result(int, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- THBaseService.openScanner_result(THBaseService.openScanner_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
Performs a deep copy on other.
- THBaseService.openScanner_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.Processor<I extends THBaseService.Iface> - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.Processor(I) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor
-
- THBaseService.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor
-
- THBaseService.put_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.put_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- THBaseService.put_args(ByteBuffer, TPut) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- THBaseService.put_args(THBaseService.put_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
Performs a deep copy on other.
- THBaseService.put_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.put_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.put_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- THBaseService.put_result(TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- THBaseService.put_result(THBaseService.put_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
Performs a deep copy on other.
- THBaseService.put_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.putMultiple_args - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.putMultiple_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- THBaseService.putMultiple_args(ByteBuffer, List<TPut>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- THBaseService.putMultiple_args(THBaseService.putMultiple_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
Performs a deep copy on other.
- THBaseService.putMultiple_args._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THBaseService.putMultiple_result - Class in org.apache.hadoop.hbase.thrift2.generated
-
- THBaseService.putMultiple_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- THBaseService.putMultiple_result(TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- THBaseService.putMultiple_result(THBaseService.putMultiple_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
Performs a deep copy on other.
- THBaseService.putMultiple_result._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- THREAD_KEEP_ALIVE_TIME_SEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
Default amount of time in seconds to keep a thread alive.
- THREAD_WAKE_FREQUENCY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for how often threads should wake up
- threadDumpingIsAlive(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
-
- ThreadMonitoring - Class in org.apache.hadoop.hbase.monitoring
-
- ThreadMonitoring() - Constructor for class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
- Threads - Class in org.apache.hadoop.hbase.util
-
Thread Utility
- Threads() - Constructor for class org.apache.hadoop.hbase.util.Threads
-
- threadWakeFrequency - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- thresholdIdleConnections - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- thrift_jsp - Class in org.apache.hadoop.hbase.generated.thrift
-
- thrift_jsp() - Constructor for class org.apache.hadoop.hbase.generated.thrift.thrift_jsp
-
- ThriftHBaseServiceHandler - Class in org.apache.hadoop.hbase.thrift2
-
This class is a glue object that connects Thrift RPC calls to the HBase client API primarily
defined in the HTableInterface.
- ThriftMetrics - Class in org.apache.hadoop.hbase.thrift
-
This class is for maintaining the various statistics of thrift server
and publishing them through the metrics interfaces.
- ThriftMetrics(int, Configuration, Class<?>) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- ThriftServer - Class in org.apache.hadoop.hbase.thrift
-
ThriftServer- this class starts up a Thrift server which implements the
Hbase API specified in the Hbase.thrift IDL file.
- ThriftServer(Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServer
-
- ThriftServer - Class in org.apache.hadoop.hbase.thrift2
-
ThriftServer - this class starts up a Thrift server which implements the HBase API specified in the
HbaseClient.thrift IDL file.
- ThriftServer() - Constructor for class org.apache.hadoop.hbase.thrift2.ThriftServer
-
- ThriftServerRunner - Class in org.apache.hadoop.hbase.thrift
-
ThriftServerRunner - this class starts up a Thrift server which implements
the Hbase API specified in the Hbase.thrift IDL file.
- ThriftServerRunner(Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServerRunner
-
- ThriftServerRunner(Configuration, ThriftServerRunner.HBaseHandler) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServerRunner
-
- ThriftServerRunner.HBaseHandler - Class in org.apache.hadoop.hbase.thrift
-
The HBaseHandler is a glue object that connects Thrift RPC calls to the
HBase client API primarily defined in the HBaseAdmin and HTable objects.
- ThriftServerRunner.HBaseHandler() - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Constructs an HBaseHandler object.
- ThriftServerRunner.HBaseHandler(Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- ThriftServerRunner.ResultScannerWrapper - Class in org.apache.hadoop.hbase.thrift
-
- ThriftServerRunner.ResultScannerWrapper(ResultScanner, boolean) - Constructor for class org.apache.hadoop.hbase.thrift.ThriftServerRunner.ResultScannerWrapper
-
- ThriftUtilities - Class in org.apache.hadoop.hbase.thrift
-
- ThriftUtilities() - Constructor for class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
- ThriftUtilities - Class in org.apache.hadoop.hbase.thrift2
-
- throwExceptionIfCallerDisconnected() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- throwExceptionIfCallerDisconnected() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Throw an exception if the caller who made this IPC call has disconnected.
- thrown - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLogSplitter
-
- ticket - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- TIllegalArgument - Exception in org.apache.hadoop.hbase.thrift2.generated
-
A TIllegalArgument exception indicates an illegal or invalid
argument was passed into a procedure.
- TIllegalArgument() - Constructor for exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- TIllegalArgument(TIllegalArgument) - Constructor for exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
Performs a deep copy on other.
- TIllegalArgument._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TIME_TO_WAIT_AFTER_SHUTDOWN_MS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
Time to wait after interrupting all worker threads.
- timedOut(long) - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- timeInQueue() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
-
- timeOfOldestEdit() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
When was the oldest edit done in the memstore
- 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
- TimeoutExceptionInjector - Class in org.apache.hadoop.hbase.errorhandling
-
Time a given process/operation and report a failure if the elapsed time exceeds the max allowed
time.
- TimeoutExceptionInjector(ForeignExceptionListener, long) - Constructor for class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
Create a generic timer for a task/process.
- timeoutInjector - Variable in class org.apache.hadoop.hbase.procedure.Procedure
-
- timerange - Variable in class org.apache.hadoop.hbase.avro.generated.AGet
-
- timerange - Variable in class org.apache.hadoop.hbase.avro.generated.AScan
-
- 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)
- timeRange - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- timeRange - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- TIMERANGE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Key for Timerange information in metadata
- TIMERANGE_TRACKER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for TimeRangeTracker
- timeRangeTracker - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- TimeRangeTracker - Class in org.apache.hadoop.hbase.regionserver
-
Stores the minimum and maximum timestamp values (both are inclusive).
- TimeRangeTracker() - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Default constructor.
- TimeRangeTracker(TimeRangeTracker) - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Copy Constructor
- TimeRangeTracker(long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- timestamp - Variable in class org.apache.hadoop.hbase.avro.generated.AColumnValue
-
- timestamp - Variable in class org.apache.hadoop.hbase.avro.generated.AGet
-
- timestamp - Variable in class org.apache.hadoop.hbase.avro.generated.AResultEntry
-
- timestamp - Variable in class org.apache.hadoop.hbase.avro.generated.AScan
-
- timestamp - Variable in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
timestamp
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
timestamp
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
timestamp
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
timestamp
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
timestamp
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
timestamp
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
timestamp
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
timestamp
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
timestamp
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- timestamp - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- timestamp - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- timestamp - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- timestamp - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- timestamp - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- timestamp - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- TIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- TIMESTAMP_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Size of the timestamp field in bytes
- TIMESTAMP_TYPE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
-
- TimeStampingFileContext - Class in org.apache.hadoop.hbase.metrics.file
-
Add timestamp to FileContext.emitRecord(String, String, OutputRecord)
.
- TimeStampingFileContext() - Constructor for class org.apache.hadoop.hbase.metrics.file.TimeStampingFileContext
-
- 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() - Constructor for class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Used during deserialization.
- 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.
- timeToLive - Variable in class org.apache.hadoop.hbase.avro.generated.AFamilyDescriptor
-
- timeToLive - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- TimeToLiveHFileCleaner - Class in org.apache.hadoop.hbase.master.cleaner
-
HFile cleaner that uses the timestamp of the hfile to determine if it should be deleted.
- TimeToLiveHFileCleaner() - Constructor for class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
-
- TimeToLiveLogCleaner - Class in org.apache.hadoop.hbase.master.cleaner
-
Log cleaner that uses the timestamp of the hlog to determine if it should
be deleted.
- TimeToLiveLogCleaner() - Constructor for class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- TIncrement - Class in org.apache.hadoop.hbase.thrift.generated
-
For increments that are not incrementColumnValue
equivalents.
- TIncrement() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- TIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- TIncrement(TIncrement) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
Performs a deep copy on other.
- TIncrement - Class in org.apache.hadoop.hbase.thrift2.generated
-
Used to perform Increment operations for a single row.
- TIncrement() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- TIncrement(ByteBuffer, List<TColumnIncrement>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- TIncrement(TIncrement) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
Performs a deep copy on other.
- TIncrement._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TIncrement._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TIOError - Exception in org.apache.hadoop.hbase.thrift2.generated
-
A TIOError exception signals that an error occurred communicating
to the HBase master or a HBase region server.
- TIOError() - Constructor for exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- TIOError(TIOError) - Constructor for exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
Performs a deep copy on other.
- TIOError._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TMutation - Class in org.apache.hadoop.hbase.thrift2.generated
-
Atomic mutation for the specified row.
- TMutation() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- TMutation(TMutation._Fields, Object) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- TMutation(TMutation) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- TMutation._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- 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
-
- toArray() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- toArray(T[]) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- toArray() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- toArray(T[]) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueSkipListSet
-
- toArray() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- toArray(T[]) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- toArray() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- toArray(T[]) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- 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
-
- toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- toBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- toBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- toByte() - Method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
- toByteArray(int, int) - Method in class org.apache.hadoop.hbase.util.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(ByteBuffer) - Static method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Convert ByteBuffer to byte array.
- toBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns a new byte array, copied from the passed ByteBuffer.
- 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
-
- toDescriptiveString() - Method in class org.apache.hadoop.hbase.master.AssignmentManager.RegionState
-
A slower (but more easy-to-read) stringification
- 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"
- 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
- 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.
- toJSON() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
Creates a JSON object for parseable exposure of monitored tasks.
- tokenHandlers - Static variable in class org.apache.hadoop.hbase.ipc.SecureClient
-
- TokenInfo - Annotation Type in org.apache.hadoop.hbase.security
-
Indicates Token related information to be used in authorizing connections
over a given RPC protocol interface.
- TokenProvider - Class in org.apache.hadoop.hbase.security.token
-
- TokenProvider() - Constructor for class org.apache.hadoop.hbase.security.token.TokenProvider
-
- TokenUtil - Class in org.apache.hadoop.hbase.security.token
-
Utility methods for obtaining authentication tokens.
- TokenUtil() - Constructor for class org.apache.hadoop.hbase.security.token.TokenUtil
-
- 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.
- 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.MultiPut
-
Deprecated.
Compile the details beyond the scope of getFingerprint (mostly
toMap from the Puts) 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.
- toMap() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- toMap() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
Creates a string map of internal details for extensible exposure of
monitored tasks.
- 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
- toString() - Method in class org.apache.hadoop.hbase.client.HConnectionManager.HConnectionKey
-
- toString() - Method in class org.apache.hadoop.hbase.client.Increment
-
- toString(int) - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a string representation of this Operation.
- toString() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a string representation of this Operation.
- toString() - Method in class org.apache.hadoop.hbase.client.Result
-
- toString() - Method in class org.apache.hadoop.hbase.client.RetriesExhaustedException.ThrowableWithExtraContext
-
- toString() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
- toString() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- toString() - Method in class org.apache.hadoop.hbase.executor.RegionTransitionData
-
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Return filter's info for debugging and logging purpose.
- toString() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- toString(int) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- toString() - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- toString(int) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- toString(int) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- toString() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- toString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- toString() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
- 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.HServerAddress
-
Deprecated.
- toString() - Method in class org.apache.hadoop.hbase.HServerInfo
-
Deprecated.
- toString() - Method in class org.apache.hadoop.hbase.HServerLoad.RegionLoad
-
- toString() - Method in class org.apache.hadoop.hbase.HServerLoad
-
- toString(int) - Method in class org.apache.hadoop.hbase.HServerLoad
-
Returns toString() with the number of requests divided by the message
interval in seconds
- toString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- toString() - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- toString() - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- toString() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
- toString() - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- toString() - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- toString() - Method in class org.apache.hadoop.hbase.io.FileLink
-
- toString() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- toString() - Method in class org.apache.hadoop.hbase.io.HbaseObjectWritable
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheColumnFamilySummary
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- toString() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- toString() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- toString() - Method in class org.apache.hadoop.hbase.io.Reference
-
- toString() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
- toString() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Call
-
- toString() - Method in class org.apache.hadoop.hbase.ipc.HBaseServer.Connection
-
- toString() - Method in class org.apache.hadoop.hbase.ipc.Invocation
-
- toString() - Method in class org.apache.hadoop.hbase.ipc.SecureServer.SecureConnection
-
- toString() - Method in class org.apache.hadoop.hbase.KeyValue
-
- 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.master.AssignmentManager.RegionState
-
- toString() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.DisableTableHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.EnableTableHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.MetaServerShutdownHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.ModifyTableHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.SplitRegionHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
-
- toString() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
- toString() - Method in class org.apache.hadoop.hbase.migration.HRegionInfo090x
-
- toString() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns String representation of the entry in form "key=value"
- toString() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLAB.Allocation
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
- toString() - Method in enum org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics.BlockMetricType
-
- toString() - Method in enum org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics.StoreMetricType
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLog.Entry
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
- toString() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- toString() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- toString() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- toString() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
- toString() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- toString() - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- toString() - Method in class org.apache.hadoop.hbase.rest.model.TableModel
-
- toString() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- toString() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- toString() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- toString() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- toString() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- toString() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- toString() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- toString() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- toString() - Method in class org.apache.hadoop.hbase.security.User
-
- toString() - Method in class org.apache.hadoop.hbase.ServerName
-
- toString() - Method in class org.apache.hadoop.hbase.snapshot.HSnapshotDescription
-
- toString(HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Returns a single line (no \n) representation of snapshot metadata.
- toString() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- toString() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- toString() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- toString() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.Args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- toString() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- toString() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- toString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- toString() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- 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.CompoundBloomFilter
-
- toString() - Method in class org.apache.hadoop.hbase.util.HashedBytes
-
- toString() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- toString() - Method in class org.apache.hadoop.hbase.util.IdLock.Entry
-
- 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.RegionSplitter.HexStringSplit
-
- toString() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- toString() - Method in enum org.apache.hadoop.hbase.zookeeper.ZKSplitLog.TaskState
-
- toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
- toString() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- 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, from its array offset to its limit, to
a string.
- 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
-
- toStringDetailed() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- toStringFirstKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- toStringLastKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- toStringMap() - Method in class org.apache.hadoop.hbase.KeyValue
-
Produces a string map for this key/value pair.
- toStringMap() - Method in class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Produces a string map for this key.
- tot_mgr_get_data_err - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_get_data_nonode - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_get_data_queued - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_get_data_result - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_get_data_retry - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_heartbeat - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_log_split_batch_err - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_log_split_batch_start - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_log_split_batch_success - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_log_split_err - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_log_split_start - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_log_split_success - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_missing_state_in_delete - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_new_unexpected_hlogs - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_node_already_exists - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_node_create_err - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_node_create_queued - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_node_create_result - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_node_create_retry - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_node_delete_err - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_node_delete_queued - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_node_delete_result - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_null_data - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_orphan_task_acquired - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_relist_logdir - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_rescan - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_rescan_deleted - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_resubmit - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_resubmit_dead_server_task - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_resubmit_failed - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_resubmit_threshold_reached - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_resubmit_unassigned - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_task_deleted - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_unacquired_orphan_done - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_mgr_wait_for_zk_delete - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_failed_to_grab_task_exception - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_failed_to_grab_task_lost_race - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_failed_to_grab_task_no_data - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_failed_to_grab_task_owned - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_final_transistion_failed - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_get_data_queued - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_get_data_result - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_get_data_retry - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_preempt_task - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_task_acquired - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_task_acquired_rescan - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_task_done - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_task_err - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_task_heartbeat - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_task_heartbeat_failed - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- tot_wkr_task_resigned - Static variable in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog.Counters
-
- total - Variable in class org.apache.hadoop.hbase.regionserver.wal.HLog.Metric
-
- TOTAL_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
A special schema metric value that means "all tables aggregated" or
"all column families aggregated" when used as a table name or a column
family name.
- totalByteSize - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- totalCompactingKVs - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
the total compacting key values in currently running compaction
- TOTALCOMPACTINGKVS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- totalKeyCount - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
The total number of keys in all chunks
- totalKeyLength - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Used for calculating the average key length.
- totalMaxKeys - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- totalOps - Variable in class org.apache.hadoop.hbase.metrics.PersistentMetricsTimeVaryingRate
-
- TotalOrderPartitioner<K extends org.apache.hadoop.io.WritableComparable<?>,V> - Class in org.apache.hadoop.hbase.mapreduce.hadoopbackport
-
Partitioner effecting a total order by reading split points from
an externally generated source.
- TotalOrderPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.hadoopbackport.TotalOrderPartitioner
-
- totalStaticBloomSizeKB - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
Total size of all Bloom filters (not necessarily loaded in memory)
- TOTALSTATICBLOOMSIZEKB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- totalStaticIndexSizeKB - Variable in class org.apache.hadoop.hbase.regionserver.metrics.RegionServerMetrics
-
Total size of all block indexes (not necessarily loaded in memory)
- TOTALSTATICINDEXSIZEKB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- totalUncompressedBytes - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Total uncompressed bytes, maybe calculate a compression ratio later.
- totalValueLength - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Used for calculating the average value length.
- TotesHRegionInfo - Interface in org.apache.hadoop.hbase.master.handler
-
Implementors tote an HRegionInfo instance.
- touch() - Method in class org.apache.hadoop.hbase.ipc.HBaseClient.Connection
-
Update lastActivity with the current time.
- TPut - Class in org.apache.hadoop.hbase.thrift2.generated
-
Used to perform Put operations for a single row.
- TPut() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- TPut(ByteBuffer, List<TColumnValue>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- TPut(TPut) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TPut
-
Performs a deep copy on other.
- TPut._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TRACE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- TRACELOG - Static variable in class org.apache.hadoop.hbase.ipc.HBaseServer
-
- trackTimestamps(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
Record the earlest Put timestamp.
- trailer - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- transferQueues(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Transfer all the queues of the specified to this region server.
- transform(KeyValue) - Method in interface org.apache.hadoop.hbase.filter.Filter
-
Give the filter a chance to transform the passed KeyValue.
- transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
By default no transformation takes place
- transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- transform(KeyValue) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- transformClusterKey(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Separate the given key into the three configurations it should contain:
hbase.zookeeper.quorum, hbase.zookeeper.client.port
and zookeeper.znode.parent
- transitionNode(ZooKeeperWatcher, HRegionInfo, ServerName, EventHandler.EventType, EventHandler.EventType, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Method that actually performs unassigned node transitions.
- transitionNode(ZooKeeperWatcher, HRegionInfo, ServerName, EventHandler.EventType, EventHandler.EventType, int, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
- transitionNodeClosed(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Transitions an existing unassigned node for the specified region which is
currently in the CLOSING state to be in the CLOSED state.
- transitionNodeOpened(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Transitions an existing unassigned node for the specified region which is
currently in the OPENING state to be in the OPENED state.
- transitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Transitions an existing unassigned node for the specified region which is
currently in the OFFLINE state to be in the OPENING state.
- transitionNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName, EventHandler.EventType) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
- TREEMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for TreeMap
- TRegionInfo - Class in org.apache.hadoop.hbase.thrift.generated
-
A TRegionInfo contains information about an HTable region.
- TRegionInfo() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- TRegionInfo(ByteBuffer, ByteBuffer, long, ByteBuffer, byte, ByteBuffer, int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- TRegionInfo(TRegionInfo) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
Performs a deep copy on other.
- TRegionInfo._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TResult - Class in org.apache.hadoop.hbase.thrift2.generated
-
if no Result is found, row and columnValues will not be set.
- TResult() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- TResult(List<TColumnValue>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- TResult(TResult) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TResult
-
Performs a deep copy on other.
- TResult._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- trigger() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
Trigger the timer immediately.
- triggerCacheRefreshForTesting() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
Trigger a cache refresh, even if its before the next cache refresh.
- triggerMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.Store
-
- triggerNow() - Method in class org.apache.hadoop.hbase.Chore
-
If the thread is currently sleeping, trigger the core to happen immediately.
- TRowMutations - Class in org.apache.hadoop.hbase.thrift2.generated
-
A TRowMutations object is used to apply a number of Mutations to a single row.
- TRowMutations() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- TRowMutations(ByteBuffer, List<TMutation>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- TRowMutations(TRowMutations) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
Performs a deep copy on other.
- TRowMutations._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TRowResult - Class in org.apache.hadoop.hbase.thrift.generated
-
Holds row name and then a map of columns to cells.
- TRowResult() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- TRowResult(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- TRowResult(TRowResult) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
Performs a deep copy on other.
- TRowResult._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- tryAtomicRegionLoad(HConnection, byte[], 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
-
- TScan - Class in org.apache.hadoop.hbase.thrift.generated
-
A Scan object is used to specify scanner parameters when opening a scanner.
- TScan() - Constructor for class org.apache.hadoop.hbase.thrift.generated.TScan
-
- TScan(TScan) - Constructor for class org.apache.hadoop.hbase.thrift.generated.TScan
-
Performs a deep copy on other.
- TScan - Class in org.apache.hadoop.hbase.thrift2.generated
-
Any timestamps in the columns are ignored, use timeRange to select by timestamp.
- TScan() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- TScan(TScan) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Performs a deep copy on other.
- TScan._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TScan._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- 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
-
- TTimeRange - Class in org.apache.hadoop.hbase.thrift2.generated
-
- TTimeRange() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- TTimeRange(long, long) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- TTimeRange(TTimeRange) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
Performs a deep copy on other.
- TTimeRange._Fields - Enum in org.apache.hadoop.hbase.thrift2.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- TTL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
-
- TTL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- tupleSchemeReadValue(TProtocol, short) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- tupleSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- TYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- TYPE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Size of the key type field in bytes
- VALID_PORT_REGEX - Static variable in class org.apache.hadoop.hbase.util.Addressing
-
- VALID_USER_TABLE_REGEX - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
- validate(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
Validate the file to see if it even belongs in the directory.
- validate(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- validate(Path) - Method in class org.apache.hadoop.hbase.master.cleaner.LogCleaner
-
- validate(HBaseProtos.SnapshotDescription, Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Convert the passed snapshot description into a 'full' snapshot description based on default
parameters, if none have been supplied.
- validate() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- validate() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- validate() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- validate() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- validate() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- validate() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- validate() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- validateHLogFilename(String) - Static method in class org.apache.hadoop.hbase.regionserver.wal.HLog
-
- validateInput(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
Deprecated.
- validateMetricChanges(Map<String, Long>) - Static method in class org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics
-
- validateRootPath(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies root directory path is a valid URI with a scheme
- validateStoreFileName(String) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Validate the store file name.
- value - Variable in class org.apache.hadoop.hbase.avro.generated.AColumnValue
-
- value - Variable in class org.apache.hadoop.hbase.avro.generated.AResultEntry
-
- value() - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value of the first column in the Result.
- value - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
The value
- value - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
amount to increment by
- value - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- value - Variable in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- value - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- value - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
the expected value, if not provided the
check is for the non-existence of the
column in question
- value - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
the expected value, if not provided the
check is for the non-existence of the
column in question
- value - Variable in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- valueClass - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient
-
- ValueFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter based on column value.
- ValueFilter() - Constructor for class org.apache.hadoop.hbase.filter.ValueFilter
-
Writable constructor, do not use.
- ValueFilter(CompareFilter.CompareOp, WritableByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.ValueFilter
-
Constructor.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.avro.generated.ACompressionAlgorithm
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.Durability
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.apache.hadoop.hbase.client.Durability
-
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.Coprocessor.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.executor.EventHandler.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.executor.ExecutorService.ExecutorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.filter.FilterList.Operator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.HConstants.Modify
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.HConstants.OperationStatusCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.io.Reference.Range
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier.Counters
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.AssignmentManager.RegionState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.TaskFinisher.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.monitoring.MonitoredTask.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(int) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest.CompactionState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteCompare
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics.BlockMetricType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics.StoreMetricType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.RegionOpeningState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScanQueryMatcher.MatchCode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.ScanType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.regionserver.StoreFile.BloomType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.replication.ReplicationZookeeper.PeerState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.access.Permission.Action
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.AuthMethod
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.QualityOfProtection
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDeleteType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDurability
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter.ERROR_CODE
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
-
Returns the enum constant of this type with the specified name.
- valueOf(String, PoolMap.PoolType, PoolMap.PoolType...) - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
-
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.zookeeper.ZKSplitLog.TaskState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.hadoop.hbase.zookeeper.ZKTable.TableState
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.hadoop.hbase.avro.generated.ACompressionAlgorithm
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.Durability
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.client.IsolationLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.Coprocessor.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.executor.EventHandler.EventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.executor.ExecutorService.ExecutorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.CompareFilter.CompareOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.Filter.ReturnCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.filter.FilterList.Operator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- values() - Static method in enum org.apache.hadoop.hbase.HConstants.Modify
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.HConstants.OperationStatusCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.hadoop.hbase.HTableDescriptor
-
A map which holds the metadata information of the table.
- values() - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.hadoop.hbase.io.HbaseMapWritable
-
- values() - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.hfile.Compression.Algorithm
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.io.Reference.Range
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.apache.hadoop.hbase.ipc.HBaseClient.ParallelResults
-
- values() - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier.Counters
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.AssignmentManager.RegionState.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.master.SplitLogManager.TaskFinisher.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.monitoring.MonitoredTask.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest.CompactionState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteCompare
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.DeleteTracker.DeleteResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Intentionally unimplemented.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics.BlockMetricType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.metrics.SchemaMetrics.StoreMetricType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.RegionOpeningState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.ScanQueryMatcher.MatchCode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.ScanType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.regionserver.StoreFile.BloomType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.replication.ReplicationZookeeper.PeerState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.access.Permission.Action
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.AuthMethod
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.QualityOfProtection
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.snapshot.ExportSnapshot.Counter
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDeleteType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TDurability
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter.ERROR_CODE
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- values() - Static method in enum org.apache.hadoop.hbase.util.PoolMap.PoolType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
-
- values() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- values(K) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- values() - Method in class org.apache.hadoop.hbase.util.SoftValueSortedMap
-
- values() - Static method in enum org.apache.hadoop.hbase.zookeeper.ZKSplitLog.TaskState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.hadoop.hbase.zookeeper.ZKTable.TableState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- VALUES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- verifyAllLogsGotReferenced(FileSystem, Path, Set<String>, HBaseProtos.SnapshotDescription, Path) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
-
Verify that all the expected logs got referenced
- verifyMetaRegionLocation(long) - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Verify .META.
is deployed and accessible.
- verifyRecoveredEdits(FileSystem, Path, HRegionInfo, HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.TakeSnapshotUtils
-
Verify one of a snapshot's region's recovered.edits, has been at the surface (file names,
length), match the original directory.
- verifyRegionState(ZooKeeperWatcher, HRegionInfo, EventHandler.EventType) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Verifies that the specified region is in the specified state in ZooKeeper.
- VerifyReplication - Class in org.apache.hadoop.hbase.mapreduce.replication
-
This map-only job compares the data from a local table with a remote one.
- VerifyReplication() - Constructor for class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
- VerifyReplication.Verifier - Class in org.apache.hadoop.hbase.mapreduce.replication
-
Map-only comparator for 2 tables
- VerifyReplication.Verifier() - Constructor for class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- VerifyReplication.Verifier.Counters - Enum in org.apache.hadoop.hbase.mapreduce.replication
-
- verifyRootRegionLocation(long) - Method in class org.apache.hadoop.hbase.catalog.CatalogTracker
-
Verify -ROOT-
is deployed and accessible.
- verifySnapshot(Path, Set<String>) - Method in class org.apache.hadoop.hbase.master.snapshot.MasterSnapshotVerifier
-
Verify that the snapshot in the directory is a valid snapshot
- verifySnapshot(Configuration, FileSystem, Path, HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Verify the validity of the snapshot
- VERSION - Static variable in interface org.apache.hadoop.hbase.coprocessor.AggregateProtocol
-
- VERSION - Static variable in class org.apache.hadoop.hbase.coprocessor.BaseEndpointCoprocessor
-
This Interfaces' version.
- VERSION - Static variable in interface org.apache.hadoop.hbase.coprocessor.example.BulkDeleteProtocol.DeleteType
-
Delete one or more version(s) of column(s).
- VERSION - Static variable in interface org.apache.hadoop.hbase.Coprocessor
-
- VERSION - Static variable in class org.apache.hadoop.hbase.HRegionInfo
-
- VERSION - Static variable in interface org.apache.hadoop.hbase.ipc.CoprocessorProtocol
-
- VERSION - Static variable in interface org.apache.hadoop.hbase.ipc.HMasterInterface
-
This Interfaces' version.
- VERSION - Static variable in interface org.apache.hadoop.hbase.ipc.HMasterRegionInterface
-
This Interfaces' version.
- VERSION - Static variable in interface org.apache.hadoop.hbase.ipc.HRegionInterface
-
This Interfaces' version.
- VERSION - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControllerProtocol
-
- VERSION - Static variable in class org.apache.hadoop.hbase.security.access.Permission
-
- VERSION - Static variable in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- VERSION - Static variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- VERSION - Static variable in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- version - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- VERSION - Static variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Current file format version
- VERSION - Static variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
The Bloom filter version.
- VERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- VERSION_FILE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
name of version file
- 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
- VERSION_PRE_092 - Static variable in class org.apache.hadoop.hbase.HRegionInfo
-
- VERSION_STRING - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- VersionAnnotation - Annotation Type in org.apache.hadoop.hbase
-
A package attribute that captures the version of hbase that was compiled.
- VersionedProtocol - Interface in org.apache.hadoop.hbase.ipc
-
Superclass of all protocols that use Hadoop RPC.
- VersionInfo - Class in org.apache.hadoop.hbase.util
-
This class finds the package info for hbase and the VersionAnnotation
information.
- VersionInfo() - Constructor for class org.apache.hadoop.hbase.util.VersionInfo
-
- VersionMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- VersionMessage.Version - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- VersionMessage.Version.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- VersionMessage.VersionOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- VersionModel - Class in org.apache.hadoop.hbase.rest.model
-
A representation of the collection of versions of the REST gateway software
components.
- VersionModel() - Constructor for class org.apache.hadoop.hbase.rest.model.VersionModel
-
Default constructor.
- VersionModel(ServletContext) - Constructor for class org.apache.hadoop.hbase.rest.model.VersionModel
-
Constructor
- VersionResource - Class in org.apache.hadoop.hbase.rest
-
Implements REST software version reporting
- VersionResource() - Constructor for class org.apache.hadoop.hbase.rest.VersionResource
-
Constructor
- VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- vintToBytes(long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- visit(Result) - Method in interface org.apache.hadoop.hbase.catalog.MetaReader.Visitor
-
Visit the catalog table row.
- visitLogEntryBeforeWrite(HRegionInfo, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
Called before each write.
- visitLogEntryBeforeWrite(HTableDescriptor, HLogKey, WALEdit) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALActionsListener
-
- visitLogEntryBeforeWrite(HRegionInfo, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- visitLogEntryBeforeWrite(HTableDescriptor, HLogKey, WALEdit) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- visitLogFiles(FileSystem, Path, FSVisitor.LogFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot log files
- visitLogFiles(FileSystem, Path, FSVisitor.LogFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over hbase log files
- visitRecoveredEdits(FileSystem, Path, FSVisitor.RecoveredEditsVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot recovered.edits
- visitReferencedFiles(FileSystem, Path, SnapshotReferenceUtil.FileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot store files, restored.edits and logs
- visitRegionRecoveredEdits(FileSystem, Path, FSVisitor.RecoveredEditsVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over recovered.edits of the specified region
- visitRegionStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot store files in the specified region
- visitRegionStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over the region store files
- visitTableRecoveredEdits(FileSystem, Path, FSVisitor.RecoveredEditsVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over each region in the table and inform about recovered.edits
- visitTableStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Iterate over the snapshot store files
- visitTableStoreFiles(FileSystem, Path, FSVisitor.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.util.FSVisitor
-
Iterate over the table store files