- 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.checkAndPut_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.client.ScannerCallable
-
- id - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- 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.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
- ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- ID_ONE - Static variable in class org.apache.hadoop.hbase.replication.TestReplicationStateBasic
-
- ID_SIZE - Static variable in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- ID_TWO - Static variable in class org.apache.hadoop.hbase.replication.TestReplicationStateBasic
-
- 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).
- IDENTIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- IDENTIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- IdentityTableMap - Class in org.apache.hadoop.hbase.mapred
-
Pass the given key and record as-is to reduce
- IdentityTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableMap
-
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
-
Write to table each key, record pair
- IdentityTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableReduce
-
- 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
-
- IDLE_TIME - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- 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
- IdReadWriteLock - Class in org.apache.hadoop.hbase.util
-
Allows multiple concurrent clients to lock on a numeric id with ReentrantReadWriteLock.
- IdReadWriteLock() - Constructor for class org.apache.hadoop.hbase.util.IdReadWriteLock
-
- idx - Variable in class org.apache.hadoop.hbase.types.StructIterator
-
- IF_OLDER_THAN_TS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- ignoreConflicts - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- ignoreZKDeleteForTesting - Variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- IllegalArgument - Class in org.apache.hadoop.hbase.thrift.generated
-
An IllegalArgument exception indicates an illegal or invalid
argument was passed into a procedure.
- IllegalArgument() - Constructor for class org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- IllegalArgument(String) - Constructor for class org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- IllegalArgument(IllegalArgument) - Constructor for class 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.
- IllegalArgumentIOException - Exception in org.apache.hadoop.hbase.exceptions
-
Exception thrown when an illegal argument is passed to a function/procedure.
- IllegalArgumentIOException() - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
-
- IllegalArgumentIOException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
-
- IllegalArgumentIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
-
- IllegalArgumentIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.IllegalArgumentIOException
-
- immediateAssignment(List<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
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.
- 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(String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
Checks that a given table operation is authorized by this permission
instance.
- implies(TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
Checks that a given table operation is authorized by this permission
instance.
- implies(TableName, KeyValue, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
Checks if this permission grants access to perform the given action on
the given table and key value.
- Import - Class in org.apache.hadoop.hbase.mapreduce
-
Import data written by
Export
.
- Import() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import
-
- Import.Importer - Class in org.apache.hadoop.hbase.mapreduce
-
Write table content out to files in hdfs.
- Import.KeyValueImporter - Class in org.apache.hadoop.hbase.mapreduce
-
A mapper that just writes out KeyValues.
- IMPORT_FORMAT_VER - Static variable in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- Importer() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- 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
-
- ImportTsv.TsvParser - Class in org.apache.hadoop.hbase.mapreduce
-
- ImportTsv.TsvParser.BadTsvLineException - Exception in org.apache.hadoop.hbase.mapreduce
-
- in - Variable in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- in - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
-
- IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- IN_MEMORY - Static variable in class org.apache.hadoop.hbase.rest.model.TestColumnSchemaModel
-
- incarnation - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- incCall(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how long a call took
- incCall(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incChildrenLatch() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor on procedure-load to restore the latch state
- incCounters(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Add some amount to a counter.
- incCounters(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Increment a named counter by some value.
- incGauge(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Add some amount to a gauge.
- incGauge(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Add some amount to a gauge.
- INCLUDE_FULL_TREE_IN_TO_STRING - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
print/debug
- INCLUDE_SYS_TABLES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
- INCLUDE_SYS_TABLES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
- includeMemstoreTS - Variable in class org.apache.hadoop.hbase.codec.prefixtree.row.TestRowEncoder
-
- includeMvccVersion - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- includeMvccVersion - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- includeMvccVersion - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
- IncludePublicAnnotationsStandardDoclet - Class in org.apache.hadoop.hbase.classification.tools
-
- IncludePublicAnnotationsStandardDoclet() - Constructor for class org.apache.hadoop.hbase.classification.tools.IncludePublicAnnotationsStandardDoclet
-
- 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.
- includesMvccVersion - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Check if the range has any overlap with TimeRange
- includeTable(TableName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- includeTimestamp(Cell) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
Update the current TimestampRange to include the timestamp from Cell
If the Key is of type DeleteColumn or DeleteFamily, it includes the
entire time range from 0 to timestamp of the key.
- InclusiveCombinedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
- InclusiveCombinedBlockCache(LruBlockCache, BlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
-
- InclusiveStopFilter - Class in org.apache.hadoop.hbase.filter
-
A Filter that stops after the given row.
- InclusiveStopFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- incMethodTime(String, long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how long a method took
- incMethodTime(String, long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incMethodTime(String, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- incNumRowKeysInBatchGet(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how many keys were in a batch get.
- incNumRowKeysInBatchGet(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incNumRowKeysInBatchGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- incNumRowKeysInBatchMutate(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how many keys were in a batch mutate.
- incNumRowKeysInBatchMutate(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- 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
- incrAppliedBatches(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- incrAppliedBatches(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- incrAppliedOps(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- incrAppliedOps(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- incrBatchesShipped(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- incrBatchesShipped(int) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrBatchesShipped(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- 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(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- increment(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- increment(Increment) - Method in class org.apache.hadoop.hbase.client.HTable
-
Increments one or more columns within a single row.
- increment(Increment) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- Increment - Class in org.apache.hadoop.hbase.client
-
Used to perform Increment operations on a single row.
- Increment(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Create a Increment operation for the specified row.
- Increment(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Create a Increment operation for the specified row.
- Increment(Increment) - Constructor for class org.apache.hadoop.hbase.client.Increment
-
Copy constructor
- increment(Increment) - Method in interface org.apache.hadoop.hbase.client.Table
-
Increments one or more columns within a single row.
- increment(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- increment(com.google.protobuf.RpcController, PingProtos.IncrementCountRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService.BlockingInterface
-
- increment(com.google.protobuf.RpcController, PingProtos.IncrementCountRequest, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService
-
rpc increment(.IncrementCountRequest) returns (.IncrementCountResponse);
- increment(com.google.protobuf.RpcController, PingProtos.IncrementCountRequest, <any>) - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService.Interface
-
rpc increment(.IncrementCountRequest) returns (.IncrementCountResponse);
- increment(com.google.protobuf.RpcController, PingProtos.IncrementCountRequest, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService.Stub
-
- increment() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Increment the current version count
- increment(Increment) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- increment(Increment, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- increment(Increment, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Perform one or more increment operations on a row.
- increment(RpcController, PingProtos.IncrementCountRequest, <any>) - Method in class org.apache.hadoop.hbase.regionserver.TestServerCustomProtocol.PingHandler
-
- increment(Increment) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- increment(RpcController, PingProtos.IncrementCountRequest, <any>) - Method in class org.apache.hadoop.hbase.security.access.TestAccessController.PingCoprocessor
-
- increment(TIncrement, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- increment(TIncrement, <any>) - 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() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.increment
-
- increment(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- increment(ByteBuffer, TIncrement, <any>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- increment(ByteBuffer, TIncrement, <any>) - 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() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.increment
-
- increment(ByteBuffer, TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- increment() - Method in class org.apache.hadoop.hbase.util.Counter
-
- INCREMENT - Static variable in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
-
- increment(long) - Method in class org.apache.hadoop.hbase.util.TimeOffsetEnvironmentEdge
-
- increment_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- increment_args(TIncrement) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- increment_args(Hbase.increment_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
Performs a deep copy on other.
- increment_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- increment_args(ByteBuffer, TIncrement) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- increment_args(THBaseService.increment_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
Performs a deep copy on other.
- increment_call(TIncrement, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.increment_call
-
- increment_call(ByteBuffer, TIncrement, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.increment_call
-
- INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- increment_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- increment_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- increment_result(Hbase.increment_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
Performs a deep copy on other.
- increment_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- increment_result(TResult, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- increment_result(THBaseService.increment_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
Performs a deep copy on other.
- INCREMENT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
-
INCREMENT = 1;
- incrementAppendCount() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Increment the count of wal appends
- incrementAppendCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementAppendSize(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Add the append size.
- incrementAppendSize(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementAppendTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Add the time it took to append.
- incrementAppendTime(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- incrementBytes(byte[], long) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Bytewise binary increment/deincrement of long contained in byte array
on given amount.
- 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(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTable
-
- incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically increments a column value.
- incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- incrementColumnValue(byte[], byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.client.Table
-
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in interface org.apache.hadoop.hbase.client.Table
-
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, Durability) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- IncrementCounterProcessorTestProtos - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type FriendsOfFriendsProcessorRequest
- IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type FriendsOfFriendsProcessorRequest
- IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type FriendsOfFriendsProcessorResponse
- IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type FriendsOfFriendsProcessorResponse
- IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- IncrementCounterProcessorTestProtos.IncCounterProcessorRequest - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type IncCounterProcessorRequest
- IncrementCounterProcessorTestProtos.IncCounterProcessorRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type IncCounterProcessorRequest
- IncrementCounterProcessorTestProtos.IncCounterProcessorRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- IncrementCounterProcessorTestProtos.IncCounterProcessorResponse - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type IncCounterProcessorResponse
- IncrementCounterProcessorTestProtos.IncCounterProcessorResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type IncCounterProcessorResponse
- IncrementCounterProcessorTestProtos.IncCounterProcessorResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- IncrementCounterProcessorTestProtos.RowSwapProcessorRequest - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type RowSwapProcessorRequest
- IncrementCounterProcessorTestProtos.RowSwapProcessorRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type RowSwapProcessorRequest
- IncrementCounterProcessorTestProtos.RowSwapProcessorRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- IncrementCounterProcessorTestProtos.RowSwapProcessorResponse - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type RowSwapProcessorResponse
- IncrementCounterProcessorTestProtos.RowSwapProcessorResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type RowSwapProcessorResponse
- IncrementCounterProcessorTestProtos.RowSwapProcessorResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- IncrementCounterProcessorTestProtos.TimeoutProcessorRequest - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type TimeoutProcessorRequest
- IncrementCounterProcessorTestProtos.TimeoutProcessorRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type TimeoutProcessorRequest
- IncrementCounterProcessorTestProtos.TimeoutProcessorRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- IncrementCounterProcessorTestProtos.TimeoutProcessorResponse - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type TimeoutProcessorResponse
- IncrementCounterProcessorTestProtos.TimeoutProcessorResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type TimeoutProcessorResponse
- IncrementCounterProcessorTestProtos.TimeoutProcessorResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- Incrementer(Region, int, int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.TestAtomicOperation.Incrementer
-
- incrementFailedDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementFailedDeleteRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of failed Delete requests.
- incrementFailedDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementFailedGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementFailedGetRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of failed Get requests.
- incrementFailedGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementFailedPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementFailedPutRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of failed Put Requests.
- incrementFailedPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementFailedScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementFailedScanRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number failed scan requests.
- incrementFailedScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementFromThrift(TIncrement) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
- incrementFromThrift(TIncrement) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- 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
-
Construct an incremental edge starting from currentTimeMillis
- IncrementingEnvironmentEdge(long) - Constructor for class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
-
Construct an incremental edge with an initial amount
- incrementIv(byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- incrementIv(byte[], int) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- incrementLogRollRequested() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- incrementLogRollRequested() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementLowReplicationLogRoll() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- incrementLowReplicationLogRoll() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementNodeDepthRecursively() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- incrementNumOccurrences(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
Each occurrence > 1 indicates a repeat of the previous entry.
- incrementNumOccurrencesOfLatestValue() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- incrementRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
- incrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of requests
- incrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementRows(List<TIncrement>, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- incrementRows(List<TIncrement>, <any>) - 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() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.incrementRows
-
- incrementRows(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- incrementRows_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- incrementRows_args(List<TIncrement>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- incrementRows_args(Hbase.incrementRows_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
Performs a deep copy on other.
- incrementRows_call(List<TIncrement>, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.incrementRows_call
-
- incrementRows_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- incrementRows_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- incrementRows_result(Hbase.incrementRows_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
Performs a deep copy on other.
- increments - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
The list of increments
- incrementSlowAppendCount() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Increment the number of appends that were slow
- incrementSlowAppendCount() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementSucessfulDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementSucessfulDeleteRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful Delete requests.
- incrementSucessfulDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementSucessfulGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementSucessfulGetRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful Get requests.
- incrementSucessfulGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementSucessfulPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementSucessfulPutRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful Put requests.
- incrementSucessfulPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementSucessfulScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- incrementSucessfulScanRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
Increment the number of successful scan requests.
- incrementSucessfulScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- incrementSyncTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
Add the time it took to sync the wal.
- incrementSyncTime(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
-
- incrementTime(long) - Method in class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
-
Increment the time by the given amount
- incRequests(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
Increment the number of requests the cluster has seen.
- incRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
-
- incrLogEditsFiltered(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- incrLogEditsFiltered(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrLogEditsFiltered(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrLogEditsFiltered(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Add on the number of log edits filtered
- incrLogEditsFiltered() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
The number of log edits filtered out.
- incrLogEditsRead() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Increment the number of log edits read by one.
- incrLogReadInBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- incrLogReadInBytes(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrLogReadInBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrLogReadInBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
increase the byte number read by source from log file
- incrLogReadInEdits(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- incrLogReadInEdits(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrLogReadInEdits(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrMiscInvocations() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
-
- incrMiscInvocations() - Method in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
-
- incrMiscInvocations() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
-
- incrOpsShipped(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- incrOpsShipped(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrOpsShipped(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incRpcCount() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- incrShippedKBs(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- incrShippedKBs(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrShippedKBs(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- incrSizeOfLogQueue(int) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- incrSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- incrSlowAppend() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Appends that have happened.
- incrSlowAppend() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSlowDelete() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Deletes that have happened.
- incrSlowDelete() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSlowGet() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Gets that have happened.
- incrSlowGet() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSlowIncrement() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Increments that have happened.
- incrSlowIncrement() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSlowPut() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment the number of slow Puts that have happened.
- incrSlowPut() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSplitRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- incrSplitRequest() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment number of a requested splits
- incrSplitRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incrSplitSuccess() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- incrSplitSuccess() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
Increment number of successful splits
- incrSplitSuccess() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
- incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
-
Called when opening a scanner on the data of this MemStoreLAB
- incScannerCount() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Called when opening a scanner on the data of this MemStoreLAB
- incSlowCall(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Increment how long a slow call took.
- incSlowCall(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incTimeInQueue(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Add how long an operation was in the queue.
- incTimeInQueue(long) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- incTimeInQueue(long) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- incValue(long) - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- INDEX_COLUMN - Static variable in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
-
the column family containing the indexed row key
- INDEX_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- INDEX_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- INDEX_KEY - Static variable in class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedListWithVisibility
-
- INDEX_KEY_MAGIC - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used as a magic return value while optimized index key feature enabled(HBASE-7845)
- INDEX_QUALIFIER - Static variable in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
-
the qualifier containing the indexed row key
- IndexBuilder - Class in org.apache.hadoop.hbase.mapreduce
-
Example map/reduce job to construct index tables that can be used to quickly
find a row based on the value of a column.
- IndexBuilder() - Constructor for class org.apache.hadoop.hbase.mapreduce.IndexBuilder
-
- IndexBuilder.Map - Class in org.apache.hadoop.hbase.mapreduce
-
Internal Mapper to be run by Hadoop.
- indexOf(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns the index of the first appearance of the value target
in
array
.
- indexOf(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns the start position of the first occurrence of the specified target
within array
, or -1
if there is no such occurrence.
- 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
-
- indexWithinComponent - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
-
- individualBlockMetaAssertions(PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.BaseTestRowData
-
- individualBlockMetaAssertions(PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.data.TestRowDataDeeper
-
- individualBlockMetaAssertions(PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.data.TestRowDataDifferentTimestamps
-
- individualBlockMetaAssertions(PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.data.TestRowDataExerciseFInts
-
- individualBlockMetaAssertions(PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.data.TestRowDataTrivial
-
- individualBlockMetaAssertions(PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.data.TestRowDataTrivialWithTags
-
- individualBlockMetaAssertions(PrefixTreeBlockMeta) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.row.TestRowData
-
- individualSearcherAssertions(CellSearcher) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.BaseTestRowData
-
- individualSearcherAssertions(CellSearcher) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.data.TestRowDataDeeper
-
- individualSearcherAssertions(CellSearcher) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.data.TestRowDataSearcherRowMiss
-
- individualSearcherAssertions(CellSearcher) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.data.TestRowDataSimple
-
- individualSearcherAssertions(CellSearcher) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.data.TestRowDataTrivial
-
- individualSearcherAssertions(CellSearcher) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.data.TestRowDataTrivialWithTags
-
- individualSearcherAssertions(CellSearcher) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.row.TestRowData
-
- inferBoundaries(TreeMap<byte[], Integer>) - Static method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- info() - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- INFO_PORT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
- INFO_SERVER_PORT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- INFOPORT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- InfoServer - Class in org.apache.hadoop.hbase.http
-
Create a Jetty embedded server to answer http requests.
- InfoServer(String, String, int, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.http.InfoServer
-
Create a status server on the given port.
- infoServer - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.Tag
-
- init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.Action
-
- init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.AddColumnAction
-
- init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.ChangeCompressionAction
-
- init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.ChangeEncodingAction
-
- init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.ChangeVersionsAction
-
- init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.DumpClusterStatusAction
-
- init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.RemoveColumnAction
-
- init(Policy.PolicyContext) - Method in class org.apache.hadoop.hbase.chaos.policies.CompositeSequentialPolicy
-
- init(Policy.PolicyContext) - Method in class org.apache.hadoop.hbase.chaos.policies.DoActionsOncePolicy
-
- init(Policy.PolicyContext) - Method in class org.apache.hadoop.hbase.chaos.policies.PeriodicPolicy
-
- init(Policy.PolicyContext) - Method in class org.apache.hadoop.hbase.chaos.policies.PeriodicRandomActionPolicy
-
- init(Policy.PolicyContext) - Method in class org.apache.hadoop.hbase.chaos.policies.Policy
-
- init(Policy.PolicyContext) - Method in class org.apache.hadoop.hbase.chaos.policies.TwoConcurrentActionPolicy
-
- init() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Support method to init constants such as timeout.
- init(RegionServerServices, Configuration, SplitLogWorker.TaskExecutor, SplitLogWorker) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Initialize internal values.
- init() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- init(RegionServerServices, Configuration, SplitLogWorker.TaskExecutor, SplitLogWorker) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
-
- init() - Method in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
-
Initialize this servlet.
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.NoCacheFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.TestGlobalFilter.RecordingFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.TestHttpServer.DummyServletFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.TestPathFilter.RecordingFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.TestServletFilter.ErrorFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.TestServletFilter.SimpleFilter
-
- init() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- init() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- init(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Initialize the key provider
- init(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyProviderForTesting
-
- init(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- init(int) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
- init(int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
-
- init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Does some quick initialization.
- init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- 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() - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
-
- init() - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
-
Giving a chance for the initialization.
- init() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancerSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
-
- init() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Clear out the metrics and re-prepare the source.
- init() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- init() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
- init(StoreScanner, StripeMultiFileWriter.WriterFactory, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Initializes multi-writer before usage.
- init() - Method in class org.apache.hadoop.hbase.regionserver.wal.MetricsEditsReplaySourceImpl
-
- init(FileSystem, Path, Configuration, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- init(FileSystem, Path, Configuration, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- init(FileSystem, Path, Configuration, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- init(FileSystem, Path, Configuration, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
-
- init(FileSystem, Path, Configuration, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
-
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Stoppable, String, UUID, ReplicationEndpoint, MetricsSource) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Instantiation method used by region servers
- init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Stoppable, String, UUID, ReplicationEndpoint, MetricsSource) - 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 wal queues
- init(ReplicationEndpoint.Context) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Initialize the replication endpoint with the given context.
- init() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Initialize the ReplicationPeers interface.
- init() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- init(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Initialize the region server replication queue interface.
- init() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
-
Initialize the replication queue client interface.
- init() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
-
- init(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Stoppable, String, UUID, ReplicationEndpoint, MetricsSource) - Method in class org.apache.hadoop.hbase.replication.ReplicationSourceDummy
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.rest.DummyFilter
-
- init(FilterConfig) - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
-
- init() - Method in class org.apache.hadoop.hbase.rest.MetricsRESTSourceImpl
-
- 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
-
- init(RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- init(RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.ExpAsStringVisibilityLabelServiceImpl
-
- init(RegionCoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
System calls this after opening of regions.
- init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- init() - Method in interface org.apache.hadoop.hbase.test.MetricsAssertHelper
-
Init helper.
- init() - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl
-
- init() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- init(String) - Method in class org.apache.hadoop.hbase.util.TestEncryptionTest.FailingKeyProvider
-
- init(WALFactory, Configuration, List<WALActionsListener>, String) - Method in class org.apache.hadoop.hbase.wal.BoundedRegionGroupingProvider
-
- init(WALFactory, Configuration, List<WALActionsListener>, String) - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- init(FileSystem, Path, Configuration, FSDataInputStream) - Method in interface org.apache.hadoop.hbase.wal.DefaultWALProvider.Reader
-
- init(FileSystem, Path, Configuration, boolean) - Method in interface org.apache.hadoop.hbase.wal.DefaultWALProvider.Writer
-
- init(WALFactory, Configuration, List<WALActionsListener>, String) - Method in class org.apache.hadoop.hbase.wal.IOTestProvider
-
- init(byte[], TableName, long, long, List<UUID>, long, long) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- init(WALFactory, Configuration, List<WALActionsListener>, String) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
Set up the provider to create wals.
- INIT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type
-
INIT = 2;
- initAdmin() - Method in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Initializes the compression after the shared stuff has been initialized.
- initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Initializes the compression after the shared stuff has been initialized.
- initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
-
- initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- initAfterHeader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- initAfterHeader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
-
- initCosts(BaseLoadBalancer.Cluster) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- initCredentials(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
- 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
-
- initCredentialsForCluster(Job, Configuration) - 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.
- initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.FilterInitializer
-
Initialize a Filter to a FilterContainer.
- initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter
-
- initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.TestGlobalFilter.RecordingFilter.Initializer
-
- initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.TestHttpServer.DummyFilterInitializer
-
- initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.TestPathFilter.RecordingFilter.Initializer
-
- initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.TestServletFilter.ErrorFilter.Initializer
-
- initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.TestServletFilter.SimpleFilter.Initializer
-
- initFirstNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- initHRegion(TableName, byte[], byte[], WAL) - Method in class org.apache.hadoop.hbase.regionserver.TestFailedAppendAndSync
-
- initHRegion(TableName, String, Configuration, byte[]...) - Static method in class org.apache.hadoop.hbase.regionserver.TestHRegion
-
- initHRegion(byte[], String, Configuration, byte[]...) - Static method in class org.apache.hadoop.hbase.regionserver.TestHRegion
-
- initHRegion(byte[], String, Configuration, boolean, byte[]...) - Static method in class org.apache.hadoop.hbase.regionserver.TestHRegion
-
- initHRegion(byte[], byte[], byte[], String, Configuration, boolean, byte[]...) - Static method in class org.apache.hadoop.hbase.regionserver.TestHRegion
-
- initHRegion(byte[], byte[], byte[], String, Configuration, boolean, Durability, WAL, byte[]...) - Static method in class org.apache.hadoop.hbase.regionserver.TestHRegion
-
- initHRegion(TableName, byte[], byte[], WAL) - Method in class org.apache.hadoop.hbase.regionserver.TestWALLockup
-
- INITIAL_STRIPE_COUNT_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The initial stripe count to create.
- initialChore() - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
-
- initialChore() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Override to run a task before we start looping.
- initialChore() - Method in class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.CountingChore
-
- initialChore() - Method in class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.FailInitialChore
-
- initialChore() - Method in class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.SleepingChore
-
- initialChore() - Method in class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.SlowChore
-
- initialClusterStatus - Variable in class org.apache.hadoop.hbase.HBaseCluster
-
the status of the cluster before we begin
- initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- initialize(HBaseProtos.EmptyMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- initialize(Server) - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
Initialize coordinated state management service.
- initialize(Server) - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
- initialize(Server) - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- initialize(P) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method should initialize any field(s) of the ColumnInterpreter with
a parsing of the passed message bytes (used on the server side).
- initialize(IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest) - Method in class org.apache.hadoop.hbase.coprocessor.TestRowProcessorEndpoint.RowProcessorEndpoint.FriendsOfFriendsProcessor
-
- initialize(IncrementCounterProcessorTestProtos.IncCounterProcessorRequest) - Method in class org.apache.hadoop.hbase.coprocessor.TestRowProcessorEndpoint.RowProcessorEndpoint.IncrementCounterProcessor
-
- initialize(IncrementCounterProcessorTestProtos.RowSwapProcessorRequest) - Method in class org.apache.hadoop.hbase.coprocessor.TestRowProcessorEndpoint.RowProcessorEndpoint.RowSwapProcessor
-
- initialize(IncrementCounterProcessorTestProtos.TimeoutProcessorRequest) - Method in class org.apache.hadoop.hbase.coprocessor.TestRowProcessorEndpoint.RowProcessorEndpoint.TimeoutProcessor
-
- initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
- initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Handle subclass specific set up.
- initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat.ExampleJobConfigurableTIF
-
- initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat.ExampleTIF
-
- initialize(JobConf, String) - Method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat.ExampleTIF
-
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.FixedRecordReader
-
- initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
- initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Handle subclass specific set up.
- 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(TableSnapshotInputFormatImpl.InputSplit, Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TestTableInputFormat.ExampleTIF
-
- initialize() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- initialize() - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
-
- initialize() - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Initialize the load balancer.
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- initialize() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Initialize the region assignment snapshot by scanning the hbase:meta table
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
Initialize this region server flush procedure manager
Uses a zookeeper based member controller.
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManager
-
Initialize a globally barriered procedure for master.
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
-
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
-
Initialize a globally barriered procedure for region servers.
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
-
- initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.procedure.SimpleMasterProcedureManager
-
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.procedure.SimpleRSProcedureManager
-
- initialize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- 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(S) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
This method should initialize any field(s) of the RowProcessor with
a parsing of the passed message bytes (used on the server side).
- initialize(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Create a default snapshot handler - uses a zookeeper based member controller.
- initialize(Server, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.TestSplitTransactionOnCluster.MockedCoordinatedStateManager
-
- initialize(Server, FileSystem, Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.rest.PerformanceEvaluation.PeInputFormat.PeRecordReader
-
- initialize(Configuration) - Static method in class org.apache.hadoop.hbase.security.Superusers
-
Should be called only once to pre-load list of super users and super
groups from Configuration.
- initialize(String[]) - Method in class org.apache.hadoop.hbase.security.visibility.LoadTestDataGeneratorWithVisibilityLabels
-
- initialize(String[]) - Method in class org.apache.hadoop.hbase.util.LoadTestDataGeneratorWithTags
-
- initialize(String[]) - Method in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
-
initialize the LoadTestDataGenerator
- initialize(String[]) - Method in class org.apache.hadoop.hbase.util.test.LoadTestDataGeneratorWithACL
-
- initializeCluster(int) - Method in class org.apache.hadoop.hbase.IntegrationTestingUtility
-
Initializes the state of the cluster.
- initializeCompressionContext(Configuration, Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
-
- initialized - Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- initializeQueues(int, Class<? extends BlockingQueue>, Object...) - Method in class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
-
- Initializer() - Constructor for class org.apache.hadoop.hbase.http.TestGlobalFilter.RecordingFilter.Initializer
-
- Initializer() - Constructor for class org.apache.hadoop.hbase.http.TestPathFilter.RecordingFilter.Initializer
-
- Initializer() - Constructor for class org.apache.hadoop.hbase.http.TestServletFilter.ErrorFilter.Initializer
-
- Initializer() - Constructor for class org.apache.hadoop.hbase.http.TestServletFilter.SimpleFilter.Initializer
-
- initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
-
- initializeScannerInConstruction() - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner
-
- initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Allows subclasses to initialize the table information.
- initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to initialize the table information.
- initializeTagHelpers() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- initializeWriter(List<RowNodeWriter>, int, TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
-
- INITIALIZING_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureState
-
INITIALIZING = 1;
- initialServers - Variable in class org.apache.hadoop.hbase.chaos.actions.Action
-
- initialStatus - Variable in class org.apache.hadoop.hbase.chaos.actions.Action
-
- initJob(String, String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Use this before submitting a TableMap job.
- initJob(String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
-
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.
- initOnBlock(PrefixTreeBlockMeta, byte[]) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
-
- initOnBlock(PrefixTreeBlockMeta, byte[]) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
-
- initOnBlock(PrefixTreeBlockMeta, byte[], boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- initOnBlock(PrefixTreeBlockMeta, byte[], int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
construct
- initOnBlock(PrefixTreeBlockMeta, byte[]) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.MvccVersionDecoder
-
- initOnBlock(PrefixTreeBlockMeta, byte[]) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.TimestampDecoder
-
- initOnBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Initializes the log reader with a particular stream (may be null).
- initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- initScanMetrics(Scan) - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
Check and initialize if application wants to collect scan metrics
- initTable() - Method in class org.apache.hadoop.hbase.IntegrationTestIngest
-
- initTable() - Method in class org.apache.hadoop.hbase.IntegrationTestIngestStripeCompactions
-
- initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
- initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(TableName, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableMap job.
- initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, 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<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a Multi TableMap job.
- initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a Multi TableMap job.
- initTableReduceJob(String, Class<? extends TableReduce>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
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
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job, Class) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Use this before submitting a TableReduce job.
- initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets up the job for reading from a table snapshot.
- initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets up the job for reading from a table snapshot.
- initTestTable() - Method in class org.apache.hadoop.hbase.util.LoadTestTool
-
- InjectAbortOnLoadListener(ProcedureExecutor<MasterProcedureEnv>) - Constructor for class org.apache.hadoop.hbase.master.procedure.MasterProcedureTestingUtility.InjectAbortOnLoadListener
-
- injectEdge(EnvironmentEdge) - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
Injects the given edge such that it becomes the managed entity.
- injectEdge(EnvironmentEdge) - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManagerTestHelper
-
- injectNonceGeneratorForTesting(ClusterConnection, NonceGenerator) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
- InlineBlockWriter - Interface in org.apache.hadoop.hbase.io.hfile
-
A way to write "inline" blocks into an
HFile
.
- InMemory() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.builder.TestTokenizerData.InMemory
-
- InMemory() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.column.TestColumnData.InMemory
-
- InMemory() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.row.TestRowData.InMemory
-
- InMemory() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.timestamp.TestTimestampData.InMemory
-
- 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_AUTOBALANCE_MAXSKEWRATIO - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Specify if ratio for data skew in M/R jobs, it goes well with the enabling hbase.mapreduce
.input.autobalance property.
- INPUT_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.TestTableMapReduceBase
-
- INPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Job parameter that specifies the input table.
- inputBytes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.row.TestRowEncoder
-
- inputKvs - Variable in class org.apache.hadoop.hbase.codec.prefixtree.row.TestRowEncoder
-
- InputSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- InputSplit(HTableDescriptor, HRegionInfo, List<String>) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- inputStream - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- inputStreamFromByteRange(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.types.PBType
-
- insert(Procedure, Procedure[]) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
When a procedure is submitted to the executor insert(proc, null) will be called.
- insert(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- insert(long, long[]) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- insert(Procedure, Procedure[]) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- insert(Table, Put, long) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter.HBaseWriterThread
-
- insert(Table, Put, long) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL.HBaseWriterThreadWithACL
-
- insert(long) - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Add a new value from the stream.
- INSERT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type
-
INSERT = 3;
- insertNewFiles(Collection<StoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Adds new files, either for from MemStore flush or bulk insert, into the structure.
- insertNewFiles(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
-
- insideBarrier() - Method in class org.apache.hadoop.hbase.procedure.SimpleRSProcedureManager.SimpleSubprocedure
-
do a log roll.
- 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
.
- installed - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- INSTANCE - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- instance - Static variable in class org.apache.hadoop.hbase.zookeeper.EmptyWatcher
-
- INSTANCE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- instantiate(Configuration, ServerStatisticTracker) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- instantiate(Configuration, RetryingCallerInterceptor, ServerStatisticTracker) - Static method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
-
- instantiate(Configuration) - Static method in class org.apache.hadoop.hbase.security.UserProvider
-
- instantiateBlockCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns the block cache or null
in case none should be used.
- instantiated - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- instantiateFilter(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Create a
Filter
to apply to all incoming keys (
KeyValues
) to
optionally not include in the job output
- instantiateHStore(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- instantiateHStore(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.TestIOFencing.BlockCompactionsInCompletionRegion
-
- instantiateRegionScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- instantiateWithCustomCtor(String, Class<?>[], Object[]) - Static method in class org.apache.hadoop.hbase.util.ReflectionUtils
-
- InstrumentedLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
-
- InstrumentedLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.InstrumentedLogWriter
-
- INT_7_RIGHT_BITS_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVIntTool
-
- INT_8TH_BIT_SET - Static variable in class org.apache.hadoop.hbase.util.vint.UVIntTool
-
- INTEGER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for an Integer
- IntegrationTestAcidGuarantees - Class in org.apache.hadoop.hbase
-
This Integration Test verifies acid guarantees across column families by frequently writing
values to rows with multiple column families and concurrently reading entire rows that expect all
column families.
- IntegrationTestAcidGuarantees() - Constructor for class org.apache.hadoop.hbase.IntegrationTestAcidGuarantees
-
- IntegrationTestBase - Class in org.apache.hadoop.hbase
-
Base class for HBase integration tests that want to use the Chaos Monkey.
- IntegrationTestBase() - Constructor for class org.apache.hadoop.hbase.IntegrationTestBase
-
- IntegrationTestBase(String) - Constructor for class org.apache.hadoop.hbase.IntegrationTestBase
-
- IntegrationTestBigLinkedList - Class in org.apache.hadoop.hbase.test
-
This is an integration test borrowed from goraci, written by Keith Turner,
which is in turn inspired by the Accumulo test called continous ingest (ci).
- IntegrationTestBigLinkedList() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedList
-
- IntegrationTestBigLinkedListWithVisibility - Class in org.apache.hadoop.hbase.test
-
IT test used to verify the deletes with visibility labels.
- IntegrationTestBigLinkedListWithVisibility() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedListWithVisibility
-
- IntegrationTestBulkLoad - Class in org.apache.hadoop.hbase.mapreduce
-
Test Bulk Load and MR on a distributed cluster.
- IntegrationTestBulkLoad() - Constructor for class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad
-
- IntegrationTestBulkLoad.CompositeKeyComparator - Class in org.apache.hadoop.hbase.mapreduce
-
Comparator used to order linkKeys so that they are passed to a reducer in order.
- IntegrationTestBulkLoad.EmptySplit - Class in org.apache.hadoop.hbase.mapreduce
-
- IntegrationTestBulkLoad.FixedRecordReader<K,V> - Class in org.apache.hadoop.hbase.mapreduce
-
- IntegrationTestBulkLoad.ITBulkLoadInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
- IntegrationTestBulkLoad.LinkChain - Class in org.apache.hadoop.hbase.mapreduce
-
Writable used as the value emitted from a pass over the hbase table.
- IntegrationTestBulkLoad.LinkedListCheckingMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Mapper to pass over the table.
- IntegrationTestBulkLoad.LinkedListCheckingReducer - Class in org.apache.hadoop.hbase.mapreduce
-
Class that does the actual checking of the links.
- IntegrationTestBulkLoad.LinkedListCreationMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Mapper that creates a linked list of KeyValues.
- IntegrationTestBulkLoad.LinkKey - Class in org.apache.hadoop.hbase.mapreduce
-
Writable class used as the key to group links in the linked list.
- IntegrationTestBulkLoad.NaturalKeyGroupingComparator - Class in org.apache.hadoop.hbase.mapreduce
-
Comparator used to figure out if a linkKey should be grouped together.
- IntegrationTestBulkLoad.NaturalKeyPartitioner - Class in org.apache.hadoop.hbase.mapreduce
-
Class to figure out what partition to send a link in the chain to.
- IntegrationTestBulkLoad.SlowMeCoproScanOperations - Class in org.apache.hadoop.hbase.mapreduce
-
- IntegrationTestDDLMasterFailover - Class in org.apache.hadoop.hbase
-
Integration test that verifies Procedure V2.
- IntegrationTestDDLMasterFailover() - Constructor for class org.apache.hadoop.hbase.IntegrationTestDDLMasterFailover
-
- IntegrationTestImportTsv - Class in org.apache.hadoop.hbase.mapreduce
-
Validate ImportTsv + LoadIncrementalHFiles on a distributed cluster.
- IntegrationTestImportTsv() - Constructor for class org.apache.hadoop.hbase.mapreduce.IntegrationTestImportTsv
-
- IntegrationTestIngest - Class in org.apache.hadoop.hbase
-
A base class for tests that do something with the cluster while running
LoadTestTool
to write and verify some data.
- IntegrationTestIngest() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngest
-
- IntegrationTestIngestStripeCompactions - Class in org.apache.hadoop.hbase
-
A test class that does the same things as IntegrationTestIngest but with stripe
compactions.
- IntegrationTestIngestStripeCompactions() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngestStripeCompactions
-
- IntegrationTestIngestWithACL - Class in org.apache.hadoop.hbase
-
/**
An Integration class for tests that does something with the cluster while running
LoadTestTool
to write and verify some data.
- IntegrationTestIngestWithACL() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngestWithACL
-
- IntegrationTestIngestWithEncryption - Class in org.apache.hadoop.hbase
-
- IntegrationTestIngestWithEncryption() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngestWithEncryption
-
- IntegrationTestIngestWithTags - Class in org.apache.hadoop.hbase
-
- IntegrationTestIngestWithTags() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngestWithTags
-
- IntegrationTestIngestWithVisibilityLabels - Class in org.apache.hadoop.hbase
-
- IntegrationTestIngestWithVisibilityLabels() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngestWithVisibilityLabels
-
- IntegrationTestingUtility - Class in org.apache.hadoop.hbase
-
Facility for integration/system tests.
- IntegrationTestingUtility() - Constructor for class org.apache.hadoop.hbase.IntegrationTestingUtility
-
- IntegrationTestingUtility(Configuration) - Constructor for class org.apache.hadoop.hbase.IntegrationTestingUtility
-
- IntegrationTestLazyCfLoading - Class in org.apache.hadoop.hbase
-
Integration test that verifies lazy CF loading during scans by doing repeated scans
with this feature while multiple threads are continuously writing values; and
verifying the result.
- IntegrationTestLazyCfLoading() - Constructor for class org.apache.hadoop.hbase.IntegrationTestLazyCfLoading
-
- IntegrationTestLoadAndVerify - Class in org.apache.hadoop.hbase.test
-
A large test which loads a lot of data that has internal references, and
verifies the data.
- IntegrationTestLoadAndVerify() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify
-
- IntegrationTestLoadAndVerify.LoadMapper - Class in org.apache.hadoop.hbase.test
-
- IntegrationTestLoadAndVerify.VerifyMapper - Class in org.apache.hadoop.hbase.test
-
- IntegrationTestLoadAndVerify.VerifyReducer - Class in org.apache.hadoop.hbase.test
-
- IntegrationTestLoadAndVerify.WALSearcher - Class in org.apache.hadoop.hbase.test
-
Tool to search missing rows in WALs and hfiles.
- IntegrationTestLoadAndVerify.WALSearcher.WALMapperSearcher - Class in org.apache.hadoop.hbase.test
-
The actual searcher mapper.
- IntegrationTestManyRegions - Class in org.apache.hadoop.hbase
-
An integration test to detect regressions in HBASE-7220.
- IntegrationTestManyRegions() - Constructor for class org.apache.hadoop.hbase.IntegrationTestManyRegions
-
- IntegrationTestMetaReplicas - Class in org.apache.hadoop.hbase
-
An integration test that starts the cluster with three replicas for the meta
It then creates a table, flushes the meta, kills the server holding the primary.
- IntegrationTestMetaReplicas() - Constructor for class org.apache.hadoop.hbase.IntegrationTestMetaReplicas
-
- IntegrationTestMTTR - Class in org.apache.hadoop.hbase.mttr
-
Integration test that should benchmark how fast HBase can recover from failures.
- IntegrationTestMTTR() - Constructor for class org.apache.hadoop.hbase.mttr.IntegrationTestMTTR
-
- IntegrationTestMTTR.LoadCallable - Class in org.apache.hadoop.hbase.mttr
-
Callable used to make sure the cluster has some load on it.
- IntegrationTestRegionReplicaPerf - Class in org.apache.hadoop.hbase
-
Test for comparing the performance impact of region replicas.
- IntegrationTestRegionReplicaPerf() - Constructor for class org.apache.hadoop.hbase.IntegrationTestRegionReplicaPerf
-
- IntegrationTestRegionReplicaReplication - Class in org.apache.hadoop.hbase
-
Integration test for testing async wal replication to secondary region replicas.
- IntegrationTestRegionReplicaReplication() - Constructor for class org.apache.hadoop.hbase.IntegrationTestRegionReplicaReplication
-
- IntegrationTestRegionReplicaReplication.DelayingMultiThreadedUpdater - Class in org.apache.hadoop.hbase
-
This extends MultiThreadedWriter to add a configurable delay to the keys written by the writer
threads to become available to the MultiThradedReader threads.
- IntegrationTestRegionReplicaReplication.DelayingMultiThreadedWriter - Class in org.apache.hadoop.hbase
-
This extends MultiThreadedWriter to add a configurable delay to the keys written by the writer
threads to become available to the MultiThradedReader threads.
- IntegrationTestReplication - Class in org.apache.hadoop.hbase.test
-
This is an integration test for replication.
- IntegrationTestReplication() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestReplication
-
- IntegrationTestReplication.ClusterID - Class in org.apache.hadoop.hbase.test
-
Wrapper around an HBase ClusterID allowing us
to get admin connections and configurations for it
- IntegrationTestReplication.VerifyReplicationLoop - Class in org.apache.hadoop.hbase.test
-
The main runner loop for the test.
- IntegrationTests - Interface in org.apache.hadoop.hbase.testclassification
-
Tag a test as 'integration/system' test, meaning that the test class has the following
characteristics:
Possibly takes hours to complete
Can be run on a mini cluster or an actual cluster
Can make changes to the given cluster (starting stopping daemons, etc)
Should not be run in parallel of other integration tests
Integration / System tests should have a class name starting with "IntegrationTest", and
should be annotated with @Category(IntegrationTests.class).
- IntegrationTestsDriver - Class in org.apache.hadoop.hbase
-
This class drives the Integration test suite execution.
- IntegrationTestsDriver() - Constructor for class org.apache.hadoop.hbase.IntegrationTestsDriver
-
- IntegrationTestTableMapReduceUtil - Class in org.apache.hadoop.hbase.mapreduce
-
Test that we add tmpjars correctly including the named dependencies.
- IntegrationTestTableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapreduce.IntegrationTestTableMapReduceUtil
-
- IntegrationTestTableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
An integration test to test
TableSnapshotInputFormat
which enables
reading directly from snapshot files without going through hbase servers.
- IntegrationTestTableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.IntegrationTestTableSnapshotInputFormat
-
- IntegrationTestTimeBoundedMultiGetRequestsWithRegionReplicas - Class in org.apache.hadoop.hbase.test
-
- IntegrationTestTimeBoundedMultiGetRequestsWithRegionReplicas() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedMultiGetRequestsWithRegionReplicas
-
- IntegrationTestTimeBoundedRequestsWithRegionReplicas - Class in org.apache.hadoop.hbase.test
-
An IntegrationTest for doing reads with a timeout, to a read-only table with region
replicas.
- IntegrationTestTimeBoundedRequestsWithRegionReplicas() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas
-
- IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader - Class in org.apache.hadoop.hbase.test
-
- IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader.TimeBoundedMultiThreadedReaderThread - Class in org.apache.hadoop.hbase.test
-
- IntegrationTestWithCellVisibilityLoadAndVerify - Class in org.apache.hadoop.hbase.test
-
A large test which loads a lot of data with cell visibility, and verifies the data.
- IntegrationTestWithCellVisibilityLoadAndVerify() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestWithCellVisibilityLoadAndVerify
-
- IntegrationTestWithCellVisibilityLoadAndVerify.LoadWithCellVisibilityMapper - Class in org.apache.hadoop.hbase.test
-
- IntegrationTestWithCellVisibilityLoadAndVerify.VerifyMapper - Class in org.apache.hadoop.hbase.test
-
- IntegrationTestZKAndFSPermissions - Class in org.apache.hadoop.hbase.test
-
An integration test which checks that the znodes in zookeeper and data in the FileSystem
are protected for secure HBase deployments.
- IntegrationTestZKAndFSPermissions() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestZKAndFSPermissions
-
- InterfaceAudience - Class in org.apache.hadoop.hbase.classification
-
Annotation to inform users of a package, class or method's intended audience.
- InterfaceAudience.LimitedPrivate - Annotation Type in org.apache.hadoop.hbase.classification
-
Intended only for the project(s) specified in the annotation.
- InterfaceAudience.Private - Annotation Type in org.apache.hadoop.hbase.classification
-
Intended for use only within Hadoop itself.
- InterfaceAudience.Public - Annotation Type in org.apache.hadoop.hbase.classification
-
Intended for use by any project or application.
- InterfaceStability - Class in org.apache.hadoop.hbase.classification
-
Annotation to inform users of how much to rely on a particular package,
class or method not changing over time.
- InterfaceStability() - Constructor for class org.apache.hadoop.hbase.classification.InterfaceStability
-
- InterfaceStability.Evolving - Annotation Type in org.apache.hadoop.hbase.classification
-
Evolving, but can break compatibility at minor release (i.e.
- InterfaceStability.Stable - Annotation Type in org.apache.hadoop.hbase.classification
-
Can evolve while retaining compatibility for minor release boundaries.;
can break compatibility only at major release (ie.
- InterfaceStability.Unstable - Annotation Type in org.apache.hadoop.hbase.classification
-
No guarantee is provided as to reliability or stability across any
level of release granularity.
- internalClose() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- internalDecodeKeyValues(DataInputStream, int, int, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- internalEncode(Cell, HFileBlockDefaultEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- internalFlushcache(WAL, long, Collection<Store>, MonitoredTask, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Flush the memstore.
- internalFlushCacheAndCommit(WAL, MonitoredTask, HRegion.PrepareFlushResult, Collection<Store>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyRequestProto.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyRequestProto
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyResponseProto.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyResponseProto
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- 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.FilterProtos.ColumnCountGetFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- 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.RegionSpecifier.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- 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.protobuf.generated.HBaseProtos.TableName.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
- internalGetFieldAccessorTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- 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.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Type
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellType
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Consistency
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Durability
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeUnit
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyState
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableState
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyState
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableState
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableState
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableState
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyState
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableState
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableState
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.State
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureState
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaScope
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaType
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleType
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Type
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.FlushAction
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.EventType
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.ScopeType
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.RecoveryMode
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
-
- internalGetValueMap() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
-
- internalPrepareFlushCache(WAL, long, Collection<Store>, MonitoredTask, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- internalRunIngestTest(long) - Method in class org.apache.hadoop.hbase.IntegrationTestIngest
-
- InternalScan - Class in org.apache.hadoop.hbase.regionserver
-
Special scanner, currently used for increment operations to
allow additional server-side arguments for Scan operations.
- InternalScan(Get) - Constructor for class org.apache.hadoop.hbase.regionserver.InternalScan
-
- InternalScan(Scan) - Constructor for class org.apache.hadoop.hbase.regionserver.InternalScan
-
- 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.
- InternalScannerIncommon(InternalScanner) - Constructor for class org.apache.hadoop.hbase.HBaseTestCase.InternalScannerIncommon
-
Deprecated.
- INTERPRETER_CLASS_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- INTERPRETER_SPECIFIC_BYTES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- InterProcessLock - Interface in org.apache.hadoop.hbase
-
An interface for an application-specific lock.
- InterProcessLock.MetadataHandler - Interface in org.apache.hadoop.hbase
-
An interface for objects that process lock metadata.
- InterProcessReadWriteLock - Interface in org.apache.hadoop.hbase
-
An interface for a distributed reader-writer lock.
- interrupt() - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
-
- 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.
- 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
- InvalidLabelException - Exception in org.apache.hadoop.hbase.security.visibility
-
- InvalidLabelException(String) - Constructor for exception org.apache.hadoop.hbase.security.visibility.InvalidLabelException
-
- InvalidQuotaSettingsException - Exception in org.apache.hadoop.hbase.quotas
-
Generic quota exceeded exception for invalid settings
- InvalidQuotaSettingsException(String) - Constructor for exception org.apache.hadoop.hbase.quotas.InvalidQuotaSettingsException
-
- 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
- InvalidWALDataException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat.InvalidWALDataException
-
- InvalidWALDataException(Throwable) - Constructor for exception org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormat.InvalidWALDataException
-
- invert(float[][]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
Copy a given matrix into a new matrix, transforming each row index and
each column index according to the inverse of the randomization scheme
that was created at construction time.
- invertIndices(int[]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
-
Given an array where each element indices[i]
represents the
randomized column index corresponding to randomized row index i
,
create a new array with the corresponding inverted indices.
- invoke(Object, Method, Object[]) - Method in class org.apache.hadoop.hbase.thrift.HbaseHandlerMetricsProxy
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- io - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_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.append_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
- IOEngine - Interface in org.apache.hadoop.hbase.io.hfile.bucket
-
A class implementing IOEngine interface supports data services for
BucketCache
.
- IOError - Class 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 class org.apache.hadoop.hbase.thrift.generated.IOError
-
- IOError(String) - Constructor for class org.apache.hadoop.hbase.thrift.generated.IOError
-
- IOError(IOError) - Constructor for class 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.
- ioHit(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- IOTestProvider - Class in org.apache.hadoop.hbase.wal
-
A WAL Provider that returns a single thread safe WAL that optionally can skip parts of our
normal interactions with HDFS.
- IOTestProvider() - Constructor for class org.apache.hadoop.hbase.wal.IOTestProvider
-
- IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_DEFAULT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- IPC_CLIENT_FALLBACK_TO_SIMPLE_AUTH_ALLOWED_KEY - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- ipcUtil - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- IPCUtil - Class in org.apache.hadoop.hbase.ipc
-
Utility to help ipc'ing.
- IPCUtil(Configuration) - Constructor for class org.apache.hadoop.hbase.ipc.IPCUtil
-
- IPCUtil.CellScannerButNoCodecException - Exception in org.apache.hadoop.hbase.ipc
-
Thrown if a cellscanner but no codec to encode it with.
- is - Variable in class org.apache.hadoop.hbase.codec.prefixtree.row.TestRowEncoder
-
- is32BitJVM() - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Determines if we are running in a 32-bit JVM.
- IS_ACTIVE_MASTER_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- IS_ACTIVE_MASTER_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- IS_DISTRIBUTED_CLUSTER - Static variable in class org.apache.hadoop.hbase.IntegrationTestingUtility
-
Configuration that controls whether this utility assumes a running/deployed cluster.
- IS_MASTER_RUNNING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
- IS_META - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by rest interface to access this metadata
attribute which denotes if it is a catalog table, either
hbase:meta
or -ROOT-
- IS_PROCEDURE_ABORTED_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
- 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
- IS_SHARED_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- isAborted() - Method in interface org.apache.hadoop.hbase.Abortable
-
Check if the server or client was aborted.
- isAborted() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- isAborted() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isAborted() - Method in class org.apache.hadoop.hbase.master.TestActiveMasterManager.DummyMaster
-
- isAborted() - Method in class org.apache.hadoop.hbase.master.TestAssignmentManagerOnCluster.MyRegionServer
-
- isAborted() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
-
- isAborted() - Method in class org.apache.hadoop.hbase.procedure.SimpleRSProcedureManager.SimpleSubprocedurePool
-
- isAborted() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isAborted() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- isAborted() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- isAborted() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
- isAborted() - Method in class org.apache.hadoop.hbase.util.MockServer
-
- isAborted() - Method in class org.apache.hadoop.hbase.zookeeper.TestZooKeeperNodeTracker.StubAbortable
-
- 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
- isAcceptableAddress(InetAddress) - Method in interface org.apache.hadoop.hbase.util.Addressing.AddressSelectionCondition
-
Condition on which to accept inet address
- isAccessControllerRunning(Connection) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- isAccessControllerRunning(Configuration) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- isActiveMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Report whether this master is currently the active master or not.
- isAfterLast() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- isAlive() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Test for the availability of the web server
- isAlive() - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
-
Check if the connection is alive
- isAlive() - Method in class org.apache.hadoop.hbase.util.HasThread
-
- isAllFiles() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- isAllowed() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- isAllSameMvccVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- isAllSameTimestamp() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- isAllSameType() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- isAllTime() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Check if it is for all time
- isAmd64() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the arch is amd64;
- isAnyMetaReplicaZnode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Is the znode of any meta replica
- 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
-
- isAutoFlush() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- isAutoFlush() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- isAvailable() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureFairRunQueues.FairObject
-
- isAvailable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isAvailable() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- isAvailable() - Static method in class org.apache.hadoop.hbase.util.UnsafeAccess
-
- 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.
- isBalancerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query the current state of the balancer
- isBalancerEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Query the state of the balancer from the Master.
- isBalancerEnabled(RpcController, MasterProtos.IsBalancerEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isBalancerEnabled(com.google.protobuf.RpcController, MasterProtos.IsBalancerEnabledRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- isBalancerEnabled(com.google.protobuf.RpcController, MasterProtos.IsBalancerEnabledRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc IsBalancerEnabled(.IsBalancerEnabledRequest) returns (.IsBalancerEnabledResponse);
- isBalancerEnabled(com.google.protobuf.RpcController, MasterProtos.IsBalancerEnabledRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc IsBalancerEnabled(.IsBalancerEnabledRequest) returns (.IsBalancerEnabledResponse);
- isBalancerEnabled(com.google.protobuf.RpcController, MasterProtos.IsBalancerEnabledRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- isBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- isBalancerOn() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- isBalancerOn() - Method in class org.apache.hadoop.hbase.zookeeper.LoadBalancerTracker
-
Return true if the balance switch is on, false otherwise
- isBatchUpdate - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- isBeforeFirst() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- isBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses BlobCopy
encoding, false otherwise.
- isBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses BlobVar
encoding, false otherwise.
- isBlockCacheEnabled() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- 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
-
- isBranch() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- isBranch() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- isBranch() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- isBulkLoaded() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- isBypass() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- isBypass() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
- isCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isCacheDataInL1() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isCacheDataInL1() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- isCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isCanceled() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- isCanceled() - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
-
- isCancelled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- isCandidateClass(Class<?>) - Method in class org.apache.hadoop.hbase.ClassFinder.And
-
- isCandidateClass(Class<?>) - Method in interface org.apache.hadoop.hbase.ClassFinder.ClassFilter
-
- isCandidateClass(Class<?>) - Method in class org.apache.hadoop.hbase.ClassFinder.Not
-
- isCandidateClass(Class<?>) - Method in class org.apache.hadoop.hbase.ClassTestFinder.TestClassFilter
-
- isCandidateFile(String, String) - Method in interface org.apache.hadoop.hbase.ClassFinder.FileNameFilter
-
- isCandidateFile(String, String) - Method in class org.apache.hadoop.hbase.ClassFinder.Not
-
- isCandidateFile(String, String) - Method in class org.apache.hadoop.hbase.ClassTestFinder.TestFileNameFilter
-
- isCandidatePath(String, boolean) - Method in class org.apache.hadoop.hbase.ClassFinder.Not
-
- isCandidatePath(String, boolean) - Method in interface org.apache.hadoop.hbase.ClassFinder.ResourcePathFilter
-
- isCandidatePath(String, boolean) - Method in class org.apache.hadoop.hbase.ClassTestFinder.TestFileNameFilter
-
- isCarryingMeta(ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- isCarryingMetaReplica(ServerName, int) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- isCarryingMetaReplica(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- isCatalogJanitorEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query on the catalog janitor state (Enabled/Disabled?)
- isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Query on the catalog janitor state (Enabled/Disabled?)
- isCatalogJanitorEnabled(RpcController, MasterProtos.IsCatalogJanitorEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isCatalogJanitorEnabled(com.google.protobuf.RpcController, MasterProtos.IsCatalogJanitorEnabledRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- isCatalogJanitorEnabled(com.google.protobuf.RpcController, MasterProtos.IsCatalogJanitorEnabledRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc IsCatalogJanitorEnabled(.IsCatalogJanitorEnabledRequest) returns (.IsCatalogJanitorEnabledResponse);
- isCatalogJanitorEnabled(com.google.protobuf.RpcController, MasterProtos.IsCatalogJanitorEnabledRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc IsCatalogJanitorEnabled(.IsCatalogJanitorEnabledRequest) returns (.IsCatalogJanitorEnabledResponse);
- isCatalogJanitorEnabled(com.google.protobuf.RpcController, MasterProtos.IsCatalogJanitorEnabledRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- isCheckExistenceOnly() - Method in class org.apache.hadoop.hbase.client.Get
-
- isCheckOnlyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
-
Returns true if only the MemStore should be checked.
- isCheckOnlyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
-
Returns true if only StoreFiles should be checked.
- isChildOfSameType(String) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Check if a child znode represents the same type(read or write) of lock
- isChildReadLock(String) - Static method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Check if a child znode represents a read lock.
- isChildWriteLock(String) - Static method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Check if a child znode represents a write lock.
- isChoreScheduled(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
-
- 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.
- isClientCellBlockSupport() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
If the client connected and specified a codec to use, then we will use this codec making
cellblocks to return.
- isClientReadable(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Returns whether the znode is supposed to be readable by the client
and DOES NOT contain sensitive information (world readable).
- isClosed() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Returns whether the connection is closed or not.
- isClosed() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isClosed() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isClosed(AdminProtos.CloseRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Check if the region is closed from a CloseRegionResponse
- isClosed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isClosed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- isClosestRowBefore() - Method in class org.apache.hadoop.hbase.client.Get
-
- isClosing() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isClosing() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isClosing() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- 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
-
- isCompacted() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
- isCompaction - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- isCompactionEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the compaction enable flag of the table is true.
- isCompactionNeeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
-
Convenience method, the equivalent of checking if result is FLUSHED_COMPACTION_NEEDED.
- isCompactionNeeded() - Method in interface org.apache.hadoop.hbase.regionserver.Region.FlushResult
-
- isCompleted(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- isCompleted() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Check if the entire procedure has globally completed, or has been aborted.
- isCompletelyFree() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- isCompressedOrEncrypted() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- isCompressTags() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isCompressTags() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- 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
-
- iscreate(InputStream) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Create a KeyValue reading from the raw InputStream.
- isData() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- isDead - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
- isDeadServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- isDeadServer(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- isDefaultMetaReplicaZnode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Is it the default meta replica's znode
- isDefaultReplica(int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
- isDefaultReplica(HRegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
- isDelayed() - Method in interface org.apache.hadoop.hbase.ipc.Delayable
-
- isDelete(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDelete(byte) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDelete(byte) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- isDelete() - Method in class org.apache.hadoop.hbase.KeyValue
-
Deprecated.
- isDelete - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- isDeleteColumnOrFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteColumns(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteColumnVersion(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleted(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- isDeleted(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- isDeleted(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
-
Check if the specified cell buffer has been deleted by a previously
seen delete.
- isDeleted(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
Check if the specified KeyValue buffer has been deleted by a previously
seen delete.
- isDeleted(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- isDeleteFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteFamilyBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- isDeleteFamilyVersion(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDeleteType(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- isDestructive() - Method in class org.apache.hadoop.hbase.chaos.monkies.CalmChaosMonkey
-
- isDestructive() - Method in class org.apache.hadoop.hbase.chaos.monkies.ChaosMonkey
-
Returns whether the CM does destructive actions (killing servers) so that a cluster restore
is needed after CM is stopped.
- isDestructive() - Method in class org.apache.hadoop.hbase.chaos.monkies.PolicyBasedChaosMonkey
-
- isDirectlyAfterNub() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayReversibleScanner
-
- isDisabledTable(ZooKeeperWatcher, TableName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
-
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLED
.
- isDisablingOrDisabledTable(ZooKeeperWatcher, TableName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
-
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#DISABLING
of ZooKeeperProtos.Table.State#DISABLED
.
- isDistributedCluster() - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
-
- isDistributedCluster() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
- isDistributedCluster() - Method in class org.apache.hadoop.hbase.IntegrationTestingUtility
-
- isDone() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- 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
-
- isDone(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isDone() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isDone() - Method in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- isDone() - Method in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
- isDoNotRetry() - Method in class org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- isEmpty() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method to check if the familyMap is empty
- isEmpty() - Method in class org.apache.hadoop.hbase.client.Result
-
Check if the underlying Cell [] is empty or not
- isEmpty() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- 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 class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- isEmpty() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- isEmpty(String) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
-
- isEmpty() - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
-
- isEmpty() - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns whether there are non-null elements in the list
- isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- isEmpty() - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
-
- 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.AbstractByteRange
-
- isEmpty(ByteRange) - Static method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- isEmpty(byte[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
-
- isEmpty(long[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
-
- isEmpty(Object[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
-
- isEmpty() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
- isEmpty(Collection<T>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
-
empty
- isEmpty() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- isEmpty() - Method in class org.apache.hadoop.hbase.util.ConstantDelayQueue
-
- isEmpty() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- isEmpty() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- isEmpty(String) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Null-safe length check.
- isEmpty() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- isEmptyQuota(QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
If throttling is enabled
- isEnabledTable(ZooKeeperWatcher, TableName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
-
Go to zookeeper and see if state of table is ZooKeeperProtos.Table.State#ENABLED
.
- isEncodedValue(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Returns true when src
appears to be positioned an encoded value,
false otherwise.
- isErr(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isErr() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isExists(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Calls fs.exists().
- isFailed() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- isFailed() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- isFailedClose() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isFailedOpen() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isFailedServer(InetSocketAddress) - Method in class org.apache.hadoop.hbase.ipc.FailedServers
-
Check if the server should be considered as bad.
- isFailoverCleanupDone() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Used by ServerShutdownHandler to make sure AssignmentManager has completed
the failover cleanup before re-assigning regions of dead servers.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Check that given column family is essential for filter to check row.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
By default, we require all scan's column families to be present.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
The only CF this filter needs is given column family.
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
-
- 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.TestCleanerChore.AlwaysDelete
-
- isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.TestCleanerChore.NeverDelete
-
- 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.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.
- isFinished() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- isFinished(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Return true if the procedure is finished.
- isFirstCellInRow() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- isFixedFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width
Float32 encoding, false otherwise.
- isFixedFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width
Float64 encoding, false otherwise.
- isFixedInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width
Int32 encoding, false otherwise.
- isFixedInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses fixed-width
Int64 encoding, false otherwise.
- isFlushCommits() - Method in class org.apache.hadoop.hbase.rest.PerformanceEvaluation.PeInputSplit
-
- isFlushSucceeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
-
Convenience method, the equivalent of checking if result is
FLUSHED_NO_COMPACTION_NEEDED or FLUSHED_NO_COMPACTION_NEEDED.
- isFlushSucceeded() - Method in interface org.apache.hadoop.hbase.regionserver.Region.FlushResult
-
- isFull() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- isFullServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- isGeneralBloomEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- isGet - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- 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.AuthUtil
-
Returns whether or not the given name should be interpreted as a group
principal.
- isGZIPOutputStreamFinishBroken() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the finish() method of GZIPOutputStream is broken
- isHadoopSecurityEnabled() - Method in class org.apache.hadoop.hbase.mapreduce.HadoopSecurityEnabledUserProviderForTesting
-
- isHadoopSecurityEnabled() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
- isHashCached() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- isHBaseSecurityEnabled() - Method in class org.apache.hadoop.hbase.mapreduce.HadoopSecurityEnabledUserProviderForTesting
-
- isHBaseSecurityEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.security.User
-
Returns whether or not secure authentication is enabled for HBase.
- isHBaseSecurityEnabled() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
- isHDFS(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- isHeartbeatMessage() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- isHFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isHFileFormat(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns true if the specified file has a valid HFile Trailer.
- isHFileFormat(FileSystem, FileStatus) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns true if the specified file has a valid HFile Trailer.
- isHFileLink(Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
- isHttpEnabled() - Method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
-
- isHttpsEnabled() - Method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
-
- isIncludesMvcc() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- isIncludesMvccVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- isIncludesTags() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- isInCompact - Variable in class org.apache.hadoop.hbase.regionserver.TestCompaction.BlockingStoreMockMaker.BlockingCompactionContext
-
- isInitialChoreComplete() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- isInitializationStartsMetaRegionAssignment() - 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.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyRequestProto.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyRequestProto
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyResponseProto.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyResponseProto
-
- 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 interface org.apache.hadoop.hbase.master.MasterServices
-
- isInitialized() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- isInitialized() - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
Checks if namespace auditor is initialized.
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- 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.FilterProtos.ColumnCountGetFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- 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.RegionSpecifier.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- 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.protobuf.generated.HBaseProtos.TableName.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
- isInitialized() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- 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
-
- isInitOnly - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- 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
-
- isInRpcCallContext() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- isInstrumentationAccessAllowed(ServletContext, HttpServletRequest, HttpServletResponse) - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
Checks the user has privileges to access to instrumentation servlets.
- isInterrupt(Throwable) - Static method in class org.apache.hadoop.hbase.util.ExceptionUtil
-
- isInterrupted() - Method in class org.apache.hadoop.hbase.util.HasThread
-
- isIsDelete() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- isKerberosPropertySetted() - Static method in class org.apache.hadoop.hbase.security.HBaseKerberosUtils
-
- isLastCellInRow() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- isLastIndex(List<?>, int) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
-
- isLatestTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
-
- isLeaf() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- isLeaf() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
methods
- isLeaf() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- isLegalFamilyName(byte[]) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isLegalFullyQualifiedTableName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
Check passed byte array, "tableName", is legal user-space table name.
- isLegalNamespaceName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
- isLegalNamespaceName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
-
Valid namespace characters are [a-zA-Z_0-9]
- isLegalTableQualifierName(byte[]) - Static method in class org.apache.hadoop.hbase.TableName
-
- isLegalTableQualifierName(byte[], boolean) - Static method in class org.apache.hadoop.hbase.TableName
-
- isLegalTableQualifierName(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TableName
-
Qualifier names can only contain 'word' characters
[a-zA-Z_0-9]
or '_', '.' or '-'.
- isLegalTableQualifierName(byte[], int, int, boolean) - Static method in class org.apache.hadoop.hbase.TableName
-
- isLink() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isLinux() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the OS is linux.
- isLoadingCfsOnDemandDefault() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isLoadingCfsOnDemandDefault() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- isLocal(Configuration) - Static method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- isLocalAddress(InetAddress) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
Given an InetAddress, checks to see if the address is a local address, by comparing the address
with all the interfaces on the node.
- isLocationAvailable(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Checks if the meta 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
-
- isLogReplaying() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- isLogSplitting() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- 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.
- isMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- isMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.FIFOCompactionPolicy
-
- isMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- isMajorCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- isMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- isMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.MockStoreFile
-
- isMajorCompaction() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- isMajorCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- isManaged() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- isMaster() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- isMasterProcedureExecutorEnabled() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Check whether the procedure executor is enabled
- isMasterProcedureExecutorEnabled() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Check whether the procedure executor is enabled
- isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- isMasterRunning() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isMasterRunning() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isMasterRunning(RpcController, MasterProtos.IsMasterRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isMasterRunning(com.google.protobuf.RpcController, MasterProtos.IsMasterRunningRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- isMasterRunning(com.google.protobuf.RpcController, MasterProtos.IsMasterRunningRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc IsMasterRunning(.IsMasterRunningRequest) returns (.IsMasterRunningResponse);
- isMasterRunning(com.google.protobuf.RpcController, MasterProtos.IsMasterRunningRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc IsMasterRunning(.IsMasterRunningRequest) returns (.IsMasterRunningResponse);
- isMasterRunning(com.google.protobuf.RpcController, MasterProtos.IsMasterRunningRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- isMatch() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
-
methods
- isMatchingTail(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Compare path component of the Path URI; e.g.
- isMatchingTail(Path, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Compare path component of the Path URI; e.g.
- isMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- isMergeable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isMerged() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMerged() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- isMerging() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMergingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isMetaEdit() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- isMetaEditFamily(byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- isMetaEditFamily(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- isMetaFile(Path) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- isMetaRegion() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isMetaRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Checks if this table is hbase:meta
region.
- isMetaRegionInTransition() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isMetaTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isMetaTable() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Checks if the table is a hbase:meta
table
- isMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- isMultiPut - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- isMultiPut - Variable in class org.apache.hadoop.hbase.util.MultiThreadedWriter
-
- isMultiPut - Variable in class org.apache.hadoop.hbase.util.TestMiniClusterLoadSequential
-
- isNamespaceEntry(String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- isNamespaceEntry(byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- isNamespaceRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isNormalizationEnabled() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if normalization enable flag of the table is true.
- isNormalizerEnabled() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Query the current state of the region normalizer
- isNormalizerEnabled() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Query the current state of the region normalizer
- isNormalizerEnabled(RpcController, MasterProtos.IsNormalizerEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- isNormalizerEnabled(com.google.protobuf.RpcController, MasterProtos.IsNormalizerEnabledRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- isNormalizerEnabled(com.google.protobuf.RpcController, MasterProtos.IsNormalizerEnabledRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc IsNormalizerEnabled(.IsNormalizerEnabledRequest) returns (.IsNormalizerEnabledResponse);
- isNormalizerEnabled(com.google.protobuf.RpcController, MasterProtos.IsNormalizerEnabledRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc IsNormalizerEnabled(.IsNormalizerEnabledRequest) returns (.IsNormalizerEnabledResponse);
- isNormalizerEnabled(com.google.protobuf.RpcController, MasterProtos.IsNormalizerEnabledRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- isNormalizerOn() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- isNormalizerOn() - Method in class org.apache.hadoop.hbase.zookeeper.RegionNormalizerTracker
-
Return true if region normalizer is on, false otherwise
- isNub() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- isNub() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- isNub() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- isNull() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
- isNull(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
is null, false
otherwise.
- isNullable() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Indicates whether this instance supports encoding null values.
- isNullable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.PBType
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.RawString
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.Struct
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.Union2
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.Union3
-
- isNullable() - Method in class org.apache.hadoop.hbase.types.Union4
-
- isNumeric(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Numeric
encoding, false otherwise.
- isNumericInfinite(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Numeric
encoding and is Infinite
, false otherwise.
- isNumericNaN(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Numeric
encoding and is NaN
, false otherwise.
- isNumericZero(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Numeric
encoding and is 0
, false otherwise.
- isOffline() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOffPeak() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- isOffPeakHour(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
- isOffPeakHour() - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
- IsolationLevel - Enum in org.apache.hadoop.hbase.client
-
Specify Isolation levels in Scan operations.
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.append
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.atomicIncrement
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.checkAndPut
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.compact
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.createTable
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAll
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRow
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRowTs
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllTs
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteTable
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.disableTable
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.enableTable
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.get
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getColumnDescriptors
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRegionInfo
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRow
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowOrBefore
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRows
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsTs
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumns
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumnsTs
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowTs
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumns
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumnsTs
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableNames
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableRegions
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVer
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVerTs
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.increment
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.incrementRows
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.isTableEnabled
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.majorCompact
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRow
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRows
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowsTs
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowTs
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerClose
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGet
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGetList
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpen
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenTs
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithPrefix
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithScan
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStop
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStopTs
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.append
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndDelete
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndPut
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.closeScanner
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteMultiple
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteSingle
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.exists
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.get
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getMultiple
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerResults
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerRows
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.increment
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.mutateRow
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.openScanner
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.put
-
- isOneway() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.putMultiple
-
- isOnLastFanNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- isOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Report the status of the server.
- isOnlineSchemaChangeAllowed(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterDDLOperationHelper
-
Check whether online schema change is allowed from config
- isOnlineSchemaChangeSupported() - Method in enum org.apache.hadoop.hbase.executor.EventType
-
- isOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpened() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpening() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpenOrMergingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpenOrMergingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpenOrSplittingNewOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isOpenOrSplittingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- 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.
- isOrderPreserving() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Indicates whether this instance writes encoded byte[]
's
which preserve the natural sort order of the unencoded value.
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.PBType
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.RawString
-
- isOrderPreserving - Variable in class org.apache.hadoop.hbase.types.Struct
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Struct
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union2
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union3
-
- isOrderPreserving() - Method in class org.apache.hadoop.hbase.types.Union4
-
- isOrphan() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- isOutOfBounds() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- isOutputtingOnTicks() - Method in class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.CountingChore
-
- isOwned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isOwned() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isParallelSeekEnabled - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
A flag that enables StoreFileScanner parallel-seeking
- isPartial() - Method in class org.apache.hadoop.hbase.client.Result
-
Whether or not the result is a partial result.
- isPBMagicPrefix(byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- isPBMagicPrefix(byte[], int, int) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- isPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- isPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
check whether the peer is enabled or not
- isPeerPath(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
Determine if a ZK path points to a peer node.
- isPendingClose() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPendingCloseOrClosing() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPendingCloseOrClosingOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPendingOpen() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPendingOpenOrOpening() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPendingOpenOrOpeningOnServer(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isPersistent() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
Memory IO engine is always unable to support persistent storage for the
cache
- isPersistent() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
File IO engine is always able to support persistent storage for the cache
- isPersistent() - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
-
- isPostWALRestoreCalled() - Method in class org.apache.hadoop.hbase.coprocessor.SampleRegionWALObserver
-
- isPostWALRestoreDeprecatedCalled() - Method in class org.apache.hadoop.hbase.coprocessor.SampleRegionWALObserver
-
- isPostWALWriteCalled() - Method in class org.apache.hadoop.hbase.coprocessor.SampleRegionWALObserver
-
- isPostWALWriteDeprecatedCalled() - Method in class org.apache.hadoop.hbase.coprocessor.SampleRegionWALObserver
-
- isPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- isPreWALRestoreCalled() - Method in class org.apache.hadoop.hbase.coprocessor.SampleRegionWALObserver
-
- isPreWALRestoreDeprecatedCalled() - Method in class org.apache.hadoop.hbase.coprocessor.SampleRegionWALObserver
-
- isPreWALWriteCalled() - Method in class org.apache.hadoop.hbase.coprocessor.SampleRegionWALObserver
-
- isPreWALWriteDeprecatedCalled() - Method in class org.apache.hadoop.hbase.coprocessor.SampleRegionWALObserver
-
- isPrimary() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- isPrimaryReplicaReader() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- isPrimaryReplicaReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- isPrimaryReplicaReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- isPrimaryReplicaStore() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- isPrimaryReplicaStore() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- isPriviThreadLocal - Variable in class org.apache.hadoop.hbase.client.TestFastFailWithoutTestUtil
-
The variable which is used as an identifier within the 2 threads.
- isProcedureDone(RpcController, MasterProtos.IsProcedureDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Checks if the specified procedure is done.
- isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManager
-
Check if the procedure is finished successfully
- isProcedureDone(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.procedure.SimpleMasterProcedureManager
-
- isProcedureDone(com.google.protobuf.RpcController, MasterProtos.IsProcedureDoneRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- isProcedureDone(com.google.protobuf.RpcController, MasterProtos.IsProcedureDoneRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc IsProcedureDone(.IsProcedureDoneRequest) returns (.IsProcedureDoneResponse);
- isProcedureDone(com.google.protobuf.RpcController, MasterProtos.IsProcedureDoneRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc IsProcedureDone(.IsProcedureDoneRequest) returns (.IsProcedureDoneResponse);
- isProcedureDone(com.google.protobuf.RpcController, MasterProtos.IsProcedureDoneRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- isProcedureFinished(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check the current state of the specified procedure.
- isProcedureFinished(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Check the current state of the specified procedure.
- isProcedureOwner(long, User) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Check if the user is this procedure's owner
- isProcedureOwner(ProcedureInfo, User) - Static method in class org.apache.hadoop.hbase.ProcedureInfo
-
Check if the user is this procedure's owner
- isPublishStatusInZk() - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
-
- isQueueRecovered() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- isQuotaEnabled() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- isQuotaEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
Returns true if the support for quota is enabled
- isQuotaEnabled() - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
- 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
-
- isRead - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.consumer.ProtobufMessageBodyConsumer
-
- isReadFromSystemAuthUser() - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- isReadFromSystemAuthUser() - Method in class org.apache.hadoop.hbase.security.visibility.ExpAsStringVisibilityLabelServiceImpl
-
- isReadOnly() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the readOnly flag of the table is set.
- isReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isReadOnly() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- isReadOnly(HRegion) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns whether this region replica can accept writes.
- isReadShortCircuitOn() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Get the HBase setting for dfs.client.read.shortcircuit from the conf or a system property.
- isReady() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Check whether the log splitter is ready to supply tasks
- isReady() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- isReadyToOffline() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state can transition to offline
- isReadyToOnline() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state can transition to online
- isRecoveredEdits(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks if the given path is the one with 'recovered.edits' dir.
- isRecovering() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isRecovering() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- ISRECOVERING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- isRecoverySupported() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- isReference() - Method in class org.apache.hadoop.hbase.regionserver.MockStoreFile
-
- isReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- isReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isReference(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isRegionCached(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Check the region cache to see whether a region is cached yet or not.
- isRegionInState(HRegionInfo, RegionState.State...) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionInState(String, RegionState.State...) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionInTransition(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionInTransition(String) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionMarkedRecoveringInZK(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
check if /hbase/recovering-regions/ exists.
- isRegionOffline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionOnline(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionReplicaReplicationEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- isRegionReplicaStoreFileRefreshEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- isRegionReplicaWaitForPrimaryFlushEnabled(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- isRegionServerRemote - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- isRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- isRegionStale(String, long) - Method in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
- 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.
- isReplay() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- isReplaying() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
- isReplaying() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- isReplicasForSameRegion(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
- isReplication(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- isRescanNode(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- 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.
- isResigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isResigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isRestoreDone(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Returns the status of a restore operation.
- isRestoreSnapshotDone(RpcController, MasterProtos.IsRestoreSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Returns the status of the requested snapshot restore/clone operation.
- isRestoreSnapshotDone(com.google.protobuf.RpcController, MasterProtos.IsRestoreSnapshotDoneRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- isRestoreSnapshotDone(com.google.protobuf.RpcController, MasterProtos.IsRestoreSnapshotDoneRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc IsRestoreSnapshotDone(.IsRestoreSnapshotDoneRequest) returns (.IsRestoreSnapshotDoneResponse);
- isRestoreSnapshotDone(com.google.protobuf.RpcController, MasterProtos.IsRestoreSnapshotDoneRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc IsRestoreSnapshotDone(.IsRestoreSnapshotDoneRequest) returns (.IsRestoreSnapshotDoneResponse);
- isRestoreSnapshotDone(com.google.protobuf.RpcController, MasterProtos.IsRestoreSnapshotDoneRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- isRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- isReturnResults() - Method in class org.apache.hadoop.hbase.client.Append
-
- isReturnResults() - Method in class org.apache.hadoop.hbase.client.Increment
-
- isReturnValueDelayed() - Method in interface org.apache.hadoop.hbase.ipc.Delayable
-
- isReversed() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether this scan is a reversed one.
- isReversed() - Method in class org.apache.hadoop.hbase.filter.Filter
-
- isReversed() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- isReversed() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- isRoot() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
-
- isRoot() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
-
methods
- isRoot() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- isRootRegion() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the descriptor represents a -ROOT-
region.
- 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.
- isRunning(ClusterManager.ServiceType, String, int) - Method in class org.apache.hadoop.hbase.HBaseClusterManager
-
- isRunning() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- isRunning() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- isRunning() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
- isRunning() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- isRunning(ClusterManager.ServiceType, String, int) - Method in class org.apache.hadoop.hbase.RESTApiClusterManager
-
- isRunning() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- 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
-
- isScanMetricsEnabled() - Method in class org.apache.hadoop.hbase.client.Scan
-
- isScheduled() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- isSecure() - Method in class org.apache.hadoop.hbase.http.HttpConfig
-
- 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.
- 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
-
- isSequenceIdFile(Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Is the given file a region open sequence id file.
- isServerDead(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Check if a server is known to be dead.
- isServerOnline(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- isServerReachable(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Check if a region server is reachable and has the expected start code
- isServerShutdownHandlerEnabled() - Method in class org.apache.hadoop.hbase.master.HMaster
-
ServerShutdownHandlerEnabled is set false before completing
assignMeta to prevent processing of ServerShutdownHandler.
- isServerShutdownHandlerEnabled() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- isServerShutdownHandlerEnabled() - Method in class org.apache.hadoop.hbase.master.TestAssignmentManagerOnCluster.MyMaster
-
- isSet(AlreadyExists._Fields) - Method in class 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.append_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.append_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
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.checkAndPut_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Hbase.checkAndPut_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_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 class 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 class 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(TAppend._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
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(TAppend._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TAuthorization._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TCellVisibility._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
-
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.append_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(THBaseService.append_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
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 class 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 class 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
- isSetAppend() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
Returns true if field append is set (has been assigned a value) and false otherwise
- isSetAppend() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
Returns true if field append is set (has been assigned a value) and false otherwise
- isSetAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_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.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.TAppend
-
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.TIncrement
-
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
- isSetAuthorizations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
Returns true if field authorizations is set (has been assigned a value) and false otherwise
- isSetAuthorizations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Returns true if field authorizations is set (has been assigned a value) and false otherwise
- isSetBatchSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
Returns true if field batchSize 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
- isSetCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
Returns true if field cellVisibility is set (has been assigned a value) and false otherwise
- isSetCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
Returns true if field cellVisibility is set (has been assigned a value) and false otherwise
- isSetCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
Returns true if field cellVisibility 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.checkAndPut_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.TAppend
-
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.TAppend
-
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.TAppend
-
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.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.TIncrement
-
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
- isSetExpression() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
-
Returns true if field expression 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.checkAndPut_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.append_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.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.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.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.append_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
- isSetLabels() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
Returns true if field labels 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 class 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 class 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 class 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 class 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 class 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
- isSetMput() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
Returns true if field mput 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
- isSetReversed() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
Returns true if field reversed is set (has been assigned a value) and false otherwise
- isSetReversed() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
Returns true if field reversed 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.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.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.TAppend
-
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.TAppend
-
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.append_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.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.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.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.append_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.TAppend
-
Returns true if field table 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.append_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.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.checkAndPut_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
- isSetTags() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
Returns true if field tags 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.Hbase.checkAndPut_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
- isSetValues() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
Returns true if field values 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
- isShowConfInServlet() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
- isShowQueueDump(Configuration) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- isShutdown() - Method in class org.apache.hadoop.hbase.ChoreService
-
- isSingleNode() - Method in interface org.apache.hadoop.hbase.security.visibility.expression.ExpressionNode
-
- isSingleNode() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- isSingleNode() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- isSingleRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- isSkipChecks() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- isSkipInit - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- isSkippable() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Indicates whether this instance is able to skip over it's encoded value.
- isSkippable() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.OrderedBlob
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.PBType
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.RawString
-
- isSkippable - Variable in class org.apache.hadoop.hbase.types.Struct
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Struct
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Union2
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Union3
-
- isSkippable() - Method in class org.apache.hadoop.hbase.types.Union4
-
- isSmall() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether this scan is a small scan
- isSnapshotCorrupted() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- isSnapshotDone(RpcController, MasterProtos.IsSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
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
- isSnapshotDone(com.google.protobuf.RpcController, MasterProtos.IsSnapshotDoneRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- isSnapshotDone(com.google.protobuf.RpcController, MasterProtos.IsSnapshotDoneRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc IsSnapshotDone(.IsSnapshotDoneRequest) returns (.IsSnapshotDoneResponse);
- isSnapshotDone(com.google.protobuf.RpcController, MasterProtos.IsSnapshotDoneRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc IsSnapshotDone(.IsSnapshotDoneRequest) returns (.IsSnapshotDoneResponse);
- isSnapshotDone(com.google.protobuf.RpcController, MasterProtos.IsSnapshotDoneRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- isSnapshotFinished(HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Check the current state of the passed snapshot.
- isSnapshotFinished(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Check the current state of the passed snapshot.
- isSnapshotOwner(HBaseProtos.SnapshotDescription, User) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Check if the user is this table snapshot's owner
- isSortColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- isSorted(Collection<byte[]>) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- isSplit() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isSplit() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isSplitParent() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isSplittable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- isSplitting() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
- isSplitting() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- isSplitting() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isSplittingNew() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- isStale() - Method in class org.apache.hadoop.hbase.client.Result
-
Whether or not the results are coming from possibly stale data.
- isStarted() - Method in class org.apache.hadoop.hbase.io.hfile.NanoTimer
-
Checking whether the timer is started
- isStarted() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- isStarted() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- isStarted(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Return true if the procedure is started.
- isStartingWithPath(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Compare of path component.
- isStartRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- isStateEnabled(byte[]) - Static method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
Parse the raw data from ZK to get a peer's state
- isStop() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
- isStop() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- isStopped() - Method in class org.apache.hadoop.hbase.chaos.monkies.CalmChaosMonkey
-
- isStopped() - Method in class org.apache.hadoop.hbase.chaos.monkies.ChaosMonkey
-
- isStopped() - Method in class org.apache.hadoop.hbase.chaos.monkies.PolicyBasedChaosMonkey
-
- isStopped() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- 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.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.master.TestActiveMasterManager.DummyMaster
-
- isStopped() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
-
- isStopped() - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- isStopped() - Method in class org.apache.hadoop.hbase.procedure.SimpleMasterProcedureManager
-
- isStopped() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isStopped() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionsCleaner
-
- isStopped() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- isStopped() - Method in interface org.apache.hadoop.hbase.Stoppable
-
- isStopped() - Method in class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.SampleStopper
-
- isStopped() - Method in class org.apache.hadoop.hbase.util.MockServer
-
- isStopped() - Method in class org.apache.hadoop.hbase.util.StoppableImplementation
-
- isStopping() - Method in class org.apache.hadoop.hbase.MockRegionServerServices
-
- isStopping() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- isStopping() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- isStopRowInclusive() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- isSuccess() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- isSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- 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
-
- ISSUE_DATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- issueDate - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- isSuperUser(User) - Static method in class org.apache.hadoop.hbase.security.Superusers
-
- isSuperUser(String) - Static method in class org.apache.hadoop.hbase.security.Superusers
-
- isSystemTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- isSystemTable() - Method in class org.apache.hadoop.hbase.TableName
-
- isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Use this api to check if the table has been created with the specified number of splitkeys
which was used while creating the given table.
- isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Use this api to check if the table has been created with the specified number of
splitkeys which was used while creating the given table.
- isTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Use this api to check if the table has been created with the specified number of
splitkeys which was used while creating the given table.
- isTableAvailable(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(String, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableAvailable(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableAvailable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableAvailable(TableName, byte[][]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- isTableAvailable(byte[], byte[][]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableAvailable(String) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- isTableAvailableAndInitialized() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
This method checks if the namespace table is assigned and then
tries to create its HTable.
- isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableDisabled(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableDisabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- isTableEnabled(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
A table that isTableEnabled == false and isTableDisabled == false
is possible.
- isTableEnabled(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- isTableEnabled(String) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(Configuration, String) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- isTableEnabled(ByteBuffer, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- isTableEnabled(ByteBuffer, <any>) - 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() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.isTableEnabled
-
- isTableEnabled(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- isTableEnabled_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- isTableEnabled_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- isTableEnabled_args(Hbase.isTableEnabled_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
Performs a deep copy on other.
- isTableEnabled_call(ByteBuffer, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.isTableEnabled_call
-
- isTableEnabled_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- isTableEnabled_result(boolean, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- isTableEnabled_result(Hbase.isTableEnabled_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
Performs a deep copy on other.
- isTableInfoExists(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Checks if a current table info file exists for the given table
- isTablePresent(TableName) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
Checks if table is present.
- isTablePresent(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
check if table is present.
- isTableRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isTableState(TableName, ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
- isTableState(TableName, boolean, ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
- isTableState(TableName, ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Checks if table is marked in specified state in ZK (using cache only).
- isTableState(TableName, boolean, ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Checks if table is marked in specified state in ZK.
- isTaskPath(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- isTerminated() - Method in class org.apache.hadoop.hbase.ChoreService
-
- isTEST_FORCE_REFRESH() - Static method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- isText(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Return true when the next encoded value in src
uses Text encoding,
false otherwise.
- isThisOurZnode(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Checks if the provided znode is the same as this region server's
- isThisOurZnode(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- isTop() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- isTopFileRegion(Reference.Range) - Static method in class org.apache.hadoop.hbase.io.Reference
-
- isTopReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- isTracking(long, long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- 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
- isUnassignable() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state is one of offline states that
can't transition to pending_close/closing (unassign/offline)
- isUnassignable(RegionState.State) - Static method in class org.apache.hadoop.hbase.master.RegionState
-
Check if a region state is one of offline states that
can't transition to pending_close/closing (unassign/offline)
- isUnassigned() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- isUnassigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isUnassigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- isUninstantiated() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- isUnix() - Static method in class org.apache.hadoop.hbase.util.JVM
-
Check if the OS is unix.
- isUnpacked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Return true when this block's buffer has been unpacked, false otherwise.
- isUpdate - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- isUpdated() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- isUpdated() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- isUsecache() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- isUseHBaseChecksum() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- isUserRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- isUseTags() - Method in class org.apache.hadoop.hbase.rest.PerformanceEvaluation.PeInputSplit
-
- isUsingL0Flush() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- isValid() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- isValid(FileStatus) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Return if the specified file is a valid store file or not.
- isValidLabel(byte[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsValidator
-
- isValidName(String) - Method in class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
-
- isValidName(String) - Method in class org.apache.hadoop.hbase.util.FSUtils.UserTableDirFilter
-
- isValidState(ScannerContext.NextState) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
- isVisibilityTagsPresent(Cell) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- isWaiting() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- isWrite - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- 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.rest.PerformanceEvaluation.PeInputSplit
-
- isWriteToWAL() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- isWriting() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- isWriting() - Method in class org.apache.hadoop.hbase.io.hfile.TestHFileBlockCompatibility.Writer
-
- ITBulkLoadInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.ITBulkLoadInputFormat
-
- IterableUtils - Class in org.apache.hadoop.hbase.util
-
Utility methods for Iterable including null-safe handlers.
- IterableUtils() - Constructor for class org.apache.hadoop.hbase.util.IterableUtils
-
- 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.CompoundConfiguration
-
- iterator() - Method in class org.apache.hadoop.hbase.HBaseTestCase.ClientScannerIncommon
-
Deprecated.
- iterator() - Method in class org.apache.hadoop.hbase.HBaseTestCase.InternalScannerIncommon
-
Deprecated.
- iterator() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- iterator() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- iterator() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
- iterator() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- iterator() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- iterator(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
-
Retrieve an
Iterator
over the values encoded in
src
.
- iterator() - Method in class org.apache.hadoop.hbase.util.BoundedArrayQueue
-
- iterator() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- iterator() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- Iterator() - Constructor for class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
-
- iterator() - Method in class org.apache.hadoop.hbase.util.ConstantDelayQueue
-
- iterator() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
- iterator() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- IV_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- IV_LENGTH - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
-