- cache - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- CACHE_BLOCKS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- CACHE_BLOCKS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- CACHE_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache data blocks on write.
- CACHE_BLOOM_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache compound bloom filter blocks on write.
- CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- CACHE_DATA_BLOCKS_COMPRESSED_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache data blocks in compressed and/or encrypted format.
- CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Key for cache data into L1 if cache is set up with more than one tier.
- CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- CACHE_FIXED_OVERHEAD - Static variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- CACHE_INDEX_BLOCKS_ON_WRITE_KEY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Configuration key to cache leaf and intermediate-level index blocks on
write.
- CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- Cacheable - Interface in org.apache.hadoop.hbase.io.hfile
-
Cacheable is an interface that allows for an object to be cached.
- CacheableDeserializer<T extends Cacheable> - Interface in org.apache.hadoop.hbase.io.hfile
-
Interface for a deserializer.
- CacheableDeserializerIdManager - Class in org.apache.hadoop.hbase.io.hfile
-
- CacheableDeserializerIdManager() - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
- cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Add block to cache.
- cacheBlock(BlockCacheKey, Cacheable) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Add block to cache (defaults to not in-memory).
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Cache the block with the specified name and buffer.
- cacheBlock(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- cacheBlock(BlockCacheKey, Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- cacheBlocks - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- cacheBlocks - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- CACHEBLOCKS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- cacheBlockWithWait(BlockCacheKey, Cacheable, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Cache the block to ramCache
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Block cache configuration.
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Cache configuration for caching data on write.
- cacheConf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- CacheConfig - Class in org.apache.hadoop.hbase.io.hfile
-
Stores all of the cache objects and configuration for a single HFile.
- CacheConfig(Configuration, HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Create a cache configuration using the specified configuration object and
family descriptor.
- CacheConfig(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Create a cache configuration using the specified configuration object and
defaults for family level settings.
- CacheConfig(CacheConfig) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Constructs a cache configuration copied from the specified configuration.
- cacheConfig - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- CachedBlock - Interface in org.apache.hadoop.hbase.io.hfile
-
- CachedEntryQueue - Class in org.apache.hadoop.hbase.io.hfile.bucket
-
A memory-bound queue that will grow until an element brings total size larger
than maxSize.
- CachedEntryQueue(long, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
- cacheFlusher - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- CacheFullException - Exception in org.apache.hadoop.hbase.io.hfile.bucket
-
- cacheLocation(TableName, RegionLocations) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- cacheLocation(TableName, ServerName, HRegionLocation) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Put a newly discovered HRegionLocation into the cache.
- cacheLocation(TableName, RegionLocations) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Put a newly discovered HRegionLocation into the cache.
- cacheSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
Total size of all elements in this queue.
- CacheStats - Class in org.apache.hadoop.hbase.io.hfile
-
Class that implements cache metrics.
- CacheStats(String) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- CacheStats(String, int) - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- caching - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- caching - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- caching - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- CACHING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- CACHING_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- calcCoverage() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
Generates a coverage multimap from split key to Regions that start with the
split key.
- calcIndexKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- calcIndexKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.RawBytesComparator
-
- calculateMutationSize(Mutation) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- calculateNumMetaBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
operate on each field
- calculateOffsetsAndLengths() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
methods
- calculateOverhead(long, long, int) - Static method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- calculateRebalancedSplits(List<InputSplit>, JobContext, long) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Calculates the number of MapReduce input splits for the map tasks.
- calculateResultSize(Result) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- calculateResultSize(List<Result>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- calculateWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
- calculateWidthOverrideOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowNodeWriter
-
- call(T) - Method in interface org.apache.hadoop.hbase.client.coprocessor.Batch.Call
-
- call(int) - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
-
- call(int) - Method in class org.apache.hadoop.hbase.client.FlushRegionCallable
-
- call(int) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
-
Computes a result, or throws an exception if unable to do so.
- call() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
Algo:
- we put the query into the execution pool.
- call(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- call(PayloadCarryingRpcController, Descriptors.MethodDescriptor, Message, Message, User, InetSocketAddress) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
Make a call, passing param
, to the IPC server running at
address
which is servicing the protocol
protocol,
with the ticket
credentials, returning the value.
- call(PayloadCarryingRpcController, Descriptors.MethodDescriptor, Message, Message, User, InetSocketAddress) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
-
Make a call, passing param
, to the IPC server running at
address
which is servicing the protocol
protocol,
with the ticket
credentials, returning the value.
- Call - Class in org.apache.hadoop.hbase.ipc
-
A call waiting for a value.
- Call(int, Descriptors.MethodDescriptor, Message, CellScanner, Message, int) - Constructor for class org.apache.hadoop.hbase.ipc.Call
-
- call(PayloadCarryingRpcController, Descriptors.MethodDescriptor, Message, Message, User, InetSocketAddress) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl
-
Make a call, passing param
, to the IPC server running at
address
which is servicing the protocol
protocol,
with the ticket
credentials, returning the value.
- call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
This is a server side method, which is invoked over RPC.
- call(BlockingService, Descriptors.MethodDescriptor, Message, CellScanner, long, MonitoredRPCHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- call() - Method in class org.apache.hadoop.hbase.master.AssignCallable
-
- call() - Method in class org.apache.hadoop.hbase.master.UnAssignCallable
-
- call() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
This call is the main execution thread of the barriered procedure.
- call() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- call(Class<T>, T, String, Class[], Object[]) - Static method in class org.apache.hadoop.hbase.util.Methods
-
- CALL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
- CALL_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- CALL_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- CALL_QUEUE_HANDLER_FACTOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- CALL_QUEUE_LEN_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
- CALL_QUEUE_READ_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- CALL_QUEUE_SCAN_SHARE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- CALL_QUEUE_TYPE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
If set to 'deadline', uses a priority queue and deprioritize long-running scans
- CALL_QUEUE_TYPE_DEADLINE_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- CALL_QUEUE_TYPE_FIFO_CONF_VALUE - Static variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- callable - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.BlockingRpcChannelImplementation
-
- callBlockingMethod(Descriptors.MethodDescriptor, RpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- callComplete() - Method in class org.apache.hadoop.hbase.ipc.Call
-
Indicate when the call is complete and the
value or error are available.
- caller - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- CallerDisconnectedException - Exception in org.apache.hadoop.hbase.ipc
-
Exception indicating that the remote host making this IPC lost its
IPC connection.
- CallerDisconnectedException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallerDisconnectedException
-
- callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.MasterCoprocessorRpcChannel
-
- callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
-
- callExecService(RpcController, Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.RegionServerCoprocessorRpcChannel
-
- callIdCnt - Variable in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
-
- callIdCnt - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
-
- callMethod(Descriptors.MethodDescriptor, PayloadCarryingRpcController, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
-
Calls method on channel
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient.RpcChannelImplementation
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationService
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, RpcCallback<Message>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService
-
- CallQueue - Class in org.apache.hadoop.hbase.thrift
-
A BlockingQueue reports waiting time in queue and queue length to
ThriftMetrics.
- CallQueue(BlockingQueue<CallQueue.Call>, ThriftMetrics) - Constructor for class org.apache.hadoop.hbase.thrift.CallQueue
-
- CallQueue.Call - Class in org.apache.hadoop.hbase.thrift
-
- callQueueSize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
This is a running count of the size of all outstanding calls by size.
- CallRunner - Class in org.apache.hadoop.hbase.ipc
-
The request processing logic, which is usually executed in thread pools provided by an
RpcScheduler
.
- calls - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
-
- callSender - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
-
- callTimeout - Variable in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
-
The time, in ms before the call should expire.
- CallTimeoutException - Exception in org.apache.hadoop.hbase.ipc
-
Client-side call timeout
- CallTimeoutException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.CallTimeoutException
-
- callWithoutRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
-
Call the server once only.
- callWithoutRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.StatsTrackingRpcRetryingCaller
-
- callWithRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
-
Retries if invocation fails.
- callWithRetries(RetryingCallable<T>, int) - Method in class org.apache.hadoop.hbase.client.StatsTrackingRpcRetryingCaller
-
- Canary - Class in org.apache.hadoop.hbase.tool
-
HBase Canary Tool, that that can be used to do
"canary monitoring" of a running HBase cluster.
- Canary() - Constructor for class org.apache.hadoop.hbase.tool.Canary
-
- Canary(Canary.Sink) - Constructor for class org.apache.hadoop.hbase.tool.Canary
-
- Canary.ExtendedSink - Interface in org.apache.hadoop.hbase.tool
-
- Canary.Monitor - Class in org.apache.hadoop.hbase.tool
-
- Canary.Monitor(Connection, String[], boolean, Canary.Sink) - Constructor for class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- Canary.RegionServerStdOutSink - Class in org.apache.hadoop.hbase.tool
-
- Canary.RegionServerStdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.Canary.RegionServerStdOutSink
-
- Canary.Sink - Interface in org.apache.hadoop.hbase.tool
-
- Canary.StdOutSink - Class in org.apache.hadoop.hbase.tool
-
- Canary.StdOutSink() - Constructor for class org.apache.hadoop.hbase.tool.Canary.StdOutSink
-
- cancel(boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- cancel() - Method in class org.apache.hadoop.hbase.client.RpcRetryingCaller
-
- cancel(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- cancel(String) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- cancel(String) - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Actively cancel a running snapshot.
- cancel(String, Throwable) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Method to cancel the Subprocedure by injecting an exception from and external source.
- cancel() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Cancels the compaction progress, setting things to 0.
- cancel() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- cancel(boolean) - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- CancelableProgressable - Interface in org.apache.hadoop.hbase.util
-
Similar interface as Progressable
but returns
a boolean to support canceling the operation.
- cancelAll() - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
-
- cancelAll(boolean) - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
-
- cancelChore(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
-
- cancelChore(ScheduledChore, boolean) - Method in class org.apache.hadoop.hbase.ChoreService
-
- cancelConnections(ServerName) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
-
Interrupt the connections to the given ip:port server.
- cancelConnections(ServerName) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
-
Interrupt the connections to the given server.
- cancelConnections(ServerName) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl
-
Interrupt the connections to the given ip:port server.
- cancellationCb - Variable in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
-
- cancelLease(String) - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Client explicitly cancels a lease.
- cancelled - Variable in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
-
- cancelMemstoreInsert(MultiVersionConsistencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Cancel a write insert that failed.
- cancelRequestedCompaction(CompactionContext) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- cancelRequestedCompaction(CompactionContext) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- canCreateBaseZNode() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- canCreateBaseZNode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- canExecute() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Is there at least one resource available to allow execution?
- canExecute(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Are there enough available resources to allow execution?
- canGrow(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- canMerge(ProcedureStoreTracker.BitSetNode) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- CANNOT_FLUSH_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.FlushAction
-
CANNOT_FLUSH = 3;
- canQueue() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
- canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- canReplicateToSameCluster() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Whether or not, the replication endpoint can replicate to it's source cluster with the same
UUID
- canReplicateToSameCluster() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- canSplit() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- canSplit() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- canUpdateTableDescriptor() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- canUpdateTableDescriptor() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- carryForwardTags(Cell) - Static method in class org.apache.hadoop.hbase.Tag
-
- carryForwardTags(List<Tag>, Cell) - Static method in class org.apache.hadoop.hbase.Tag
-
- castToCellType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- castToCellType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- castToCellType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- castToCellType(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
The response message comes as type S.
- castToReturnType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- castToReturnType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- castToReturnType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- castToReturnType(T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
provides casting opportunity between the data types.
- CATALOG_FAMILY - Static variable in class org.apache.hadoop.hbase.HConstants
-
The catalog family
- CATALOG_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The catalog family as a string
- CatalogJanitor - Class in org.apache.hadoop.hbase.master
-
A janitor for the catalog tables.
- catalogJanitorEnabled - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- cConnection - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- cConnection - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- ceiling(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- Cell - Interface in org.apache.hadoop.hbase
-
The unit of storage in HBase consisting of the following fields:
- cell - Variable in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- CELL_BLOCK_CODEC_CLASS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- CELL_BLOCK_COMPRESSOR_CLASS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- CELL_BLOCK_META_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- CELL_BLOCK_META_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- CELL_CODEC_CLS_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- CELL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- CELL_SKIPLIST_SET - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for CellSkipListSet
- CELL_TTL_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- CELL_TYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
- CELL_VISIBILITY_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- CellCodec - Class in org.apache.hadoop.hbase.codec
-
Basic Cell codec that just writes out all the individual elements of a Cell.
- CellCodec() - Constructor for class org.apache.hadoop.hbase.codec.CellCodec
-
- CellCodecWithTags - Class in org.apache.hadoop.hbase.codec
-
Basic Cell codec that just writes out all the individual elements of a Cell including the tags.
- CellCodecWithTags() - Constructor for class org.apache.hadoop.hbase.codec.CellCodecWithTags
-
- CellComparator - Class in org.apache.hadoop.hbase
-
Compare two HBase cells.
- CellComparator() - Constructor for class org.apache.hadoop.hbase.CellComparator
-
- CellComparator.RowComparator - Class in org.apache.hadoop.hbase
-
Counter part for the KeyValue.RowOnlyComparator
- CellComparator.RowComparator() - Constructor for class org.apache.hadoop.hbase.CellComparator.RowComparator
-
- CellCounter - Class in org.apache.hadoop.hbase.mapreduce
-
A job with a a map and reduce phase to count cells in a table.
- CellCounter() - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCounter
-
- CellCreator - Class in org.apache.hadoop.hbase.mapreduce
-
Facade to create Cells for HFileOutputFormat.
- CellCreator(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- cellDecoder - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- cellEncoder - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- cellFromHBase(Cell) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a list of Thrift TCell "struct" based on
an Hbase Cell object.
- cellFromHBase(Cell[]) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a list of Thrift TCell "struct" based on
an Hbase Cell array.
- CellMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellMessage.Cell - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.Cell
- CellMessage.Cell.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.Cell
- CellMessage.CellOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a cell.
- CellModel() - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Default constructor
- CellModel(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor
- CellModel(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor
- CellModel(Cell) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor from KeyValue
- CellModel(byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor
- CellModel(byte[], byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.CellModel
-
Constructor
- CellOutputStream - Interface in org.apache.hadoop.hbase.io
-
Accepts a stream of Cells.
- CellProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- CellProtos.Cell - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Cell
- CellProtos.Cell.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Cell
- CellProtos.CellOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- CellProtos.CellType - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum CellType
- CellProtos.KeyValue - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type KeyValue
- CellProtos.KeyValue.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type KeyValue
- CellProtos.KeyValueOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- CELLS_PER_RESULT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- CellScannable - Interface in org.apache.hadoop.hbase
-
Implementer can return a CellScanner over its Cell content.
- cellScanner() - Method in interface org.apache.hadoop.hbase.CellScannable
-
- CellScanner - Interface in org.apache.hadoop.hbase
-
An interface for iterating through a sequence of cells.
- cellScanner() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- cellScanner() - Method in class org.apache.hadoop.hbase.client.Result
-
- cellScanner() - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
-
- cellScanner() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- cellScanner - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- CellScannerPosition - Enum in org.apache.hadoop.hbase.codec.prefixtree.scanner
-
An indicator of the state of the scanner after an operation such as nextCell() or
positionAt(..).
- CellSearcher - Interface in org.apache.hadoop.hbase.codec.prefixtree.scanner
-
Methods for seeking to a random
Cell
inside a sorted collection of cells.
- CellSetMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellSetMessage.CellSet - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.CellSet
- CellSetMessage.CellSet.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.CellSet
- CellSetMessage.CellSet.Row - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row
- CellSetMessage.CellSet.Row.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row
- CellSetMessage.CellSet.RowOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellSetMessage.CellSetOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- CellSetModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a grouping of cells.
- CellSetModel() - Constructor for class org.apache.hadoop.hbase.rest.model.CellSetModel
-
Constructor
- CellSetModel(List<RowModel>) - Constructor for class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- CellSkipListSet - Class in org.apache.hadoop.hbase.regionserver
-
- cellsPerHeartbeatCheck - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- CellTypeEncoder - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.other
-
Detect if every KV has the same KeyValue.Type, in which case we don't need to store it for each
KV.
- CellTypeEncoder() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
-
- cellTypeEncoder - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- CellUtil - Class in org.apache.hadoop.hbase
-
Utility methods helpful slinging
Cell
instances.
- CellUtil() - Constructor for class org.apache.hadoop.hbase.CellUtil
-
- CellVisibility - Class in org.apache.hadoop.hbase.security.visibility
-
This contains a visibility expression which can be associated with a cell.
- CellVisibility(String) - Constructor for class org.apache.hadoop.hbase.security.visibility.CellVisibility
-
- cellVisibility - Variable in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- cellVisibility - Variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- cellVisibility - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- cellVisibilityExpr - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- CF_ATTRIBUTE_EARLY_OUT - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
-
Configuration or CF schema option for early termination of access checks
if table or CF permissions grant access.
- CF_RENAME_PROP - Static variable in class org.apache.hadoop.hbase.mapreduce.Import
-
- CFNAME - Static variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- ChainWALEntryFilter - Class in org.apache.hadoop.hbase.replication
-
A
WALEntryFilter
which contains multiple filters and applies them
in chain order
- ChainWALEntryFilter(WALEntryFilter...) - Constructor for class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
-
- ChainWALEntryFilter(List<WALEntryFilter>) - Constructor for class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
-
- chance - Variable in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- CHANCE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
- ChangedReadersObserver - Interface in org.apache.hadoop.hbase.regionserver
-
If set of MapFile.Readers in Store change, implementors are notified.
- channel - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.hadoop.hbase.ipc.AsyncServerResponseHandler
-
- channelRead(ReadableByteChannel, ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- channelRead(ChannelHandlerContext, Object) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
-
- channelUnregistered(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
-
- channelWrite(GatheringByteChannel, BufferChain) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- CHARSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- check(Put) - Method in interface org.apache.hadoop.hbase.constraint.Constraint
-
Check a
Put
to ensure it is valid for the table.
- CHECK_AUTHS_FOR_MUTATION - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
- CHECK_MUTATE_FAILED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CHECK_MUTATE_FAILED_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CHECK_MUTATE_PASSED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CHECK_MUTATE_PASSED_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- checkAccess(UserGroupInformation, FileStatus, FsAction) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Throw an exception if an action is not permitted by a user on a file.
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in interface org.apache.hadoop.hbase.client.Table
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, AsyncMethodCallback<THBaseService.AsyncClient.checkAndDelete_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, AsyncMethodCallback<THBaseService.AsyncClient.checkAndDelete_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically checks if a row/family/qualifier value matches the expected value.
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in interface org.apache.hadoop.hbase.client.Table
-
Atomically checks if a row/family/qualifier value matches the expected value.
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Mutation, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, Mutation, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Atomically checks if a row/family/qualifier value matches the expected val
If it does, it performs the row mutations.
- checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTable
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in interface org.apache.hadoop.hbase.client.Table
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.checkAndPut_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.checkAndPut_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, AsyncMethodCallback<THBaseService.AsyncClient.checkAndPut_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, AsyncMethodCallback<THBaseService.AsyncClient.checkAndPut_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Atomically checks if a row/family/qualifier value matches the expected
value.
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- checkAndRemoveTableState(TableName, ZooKeeperProtos.Table.State, boolean) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
If the table is found in the given state the in-memory state is removed.
- checkAndRemoveTableState(TableName, ZooKeeperProtos.Table.State, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
If the table is found in the given state the in-memory state is removed.
- checkAndRowMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, RowMutations, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkAndRowMutate(byte[], byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, RowMutations, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Atomically checks if a row/family/qualifier value matches the expected val
If it does, it performs the row mutations.
- checkAndSetTimeout() - Method in class org.apache.hadoop.hbase.ipc.Call
-
Check if the call did timeout.
- checkAndSetZNodeAcls() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
On master start, we check the znode ACLs under the root directory and set the ACLs properly
if needed.
- checkAndUpdateNamespaceRegionQuota(TableName, int) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- checkBlockBoundary() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
At a block boundary, write all the inline blocks and opens new block.
- checkClosingState(HRegionInfo, CloseRegionCoordination.CloseRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.CloseRegionCoordination
-
Called before actual region closing to check that we can do close operation
on this region.
- checkClosingState(HRegionInfo, CloseRegionCoordination.CloseRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination
-
In ZK-based version we're checking for bad znode state, e.g.
- checkClosingState(ZooKeeperWatcher, HRegionInfo, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
- checkClusterIdExists(FileSystem, Path, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks that a cluster ID file exists in the HBase root directory
- checkColFamDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Check all files in a column family dir.
- checkColumn(byte[], int, int, byte) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Checks if the column is present in the list of requested columns by returning the match code
instance.
- checkColumn(byte[], int, int, byte) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
Checks if the column is present in the list of requested columns by returning the match code
instance.
- checkColumn(byte[], int, int, byte) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
Checks if the column is present in the list of requested columns by returning the match code
instance.
- checkDfsSafeMode(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Check whether dfs is in safemode.
- checkDifferencesWithOldPlan(Map<TableName, Integer>, Map<String, Map<String, Float>>, FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Compares two plans and check whether the locality dropped or increased
(prints the information as a string) also prints the baseline locality
- checkExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Check if the specified node exists.
- checkFailed() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
Throws an IOException back out if one is currently stored.
- checkFamilies(Collection<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkFamilies(Collection<byte[]>) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Check the collection of families for validity.
- checkFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Checks to see if the file system is still accessible.
- checkFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Checks to see if the file system is still accessible.
- checkFileSystemAvailable(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Checks to see if the specified file system is available
- checkFlushed() - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
-
- checkForAnd(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'AND'
- checkForClusterFreeMemoryLimit(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
-
Checks whether we have enough heap memory left out after portion for Memstore and Block cache.
- checkFormatVersion(int) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Checks the given
HFile
format version, and throws an exception if
invalid.
- checkForOr(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'OR'
- checkForSkip(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'SKIP'
- checkForWhile(byte[], int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Checks if the current index of filter string we are on is the beginning of the keyword 'WHILE'
- checkHBaseAvailable(Configuration) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Check to see if HBase is running.
- checkHFile(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Checks a path to see if it is a valid hfile.
- checkIfBaseNodeAvailable() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Checks if the baseznode set as per the property 'zookeeper.znode.parent'
exists.
- checkIfRegionServerIsRemote() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
compare the local machine hostname with region server's hostname
to decide if hbase client connects to a remote region server
- checkIn(PrefixTreeArraySearcher) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.ArraySearcherPool
-
- checkIn(CellSearcher) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.decode.DecoderFactory
-
- checkIn(PrefixTreeEncoder) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderFactory
-
- checkIn(PrefixTreeEncoder) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderPool
-
- checkIn(PrefixTreeEncoder) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderPoolImpl
-
- checkIOException(IOException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
-
Examine passed IOException.
- checkKey(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Checks that the given Cell's key does not violate the key order.
- checkKeyValueLen() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
Check key and value lengths are wholesome.
- checkLen(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- checkLockExists(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- checkNamespaceTableAndRegionQuota(TableName, int) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- checkOnlyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
-
StoreFiles will not be scanned.
- checkOnlyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
-
MemStore will not be scanned.
- checkOOME(Throwable) - Method in interface org.apache.hadoop.hbase.ipc.HBaseRPCErrorHandler
-
Take actions on the event of an OutOfMemoryError.
- checkOOME(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- checkOpen() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Called to verify that this server is up and running.
- checkOut(ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.ArraySearcherPool
-
- checkOut(ByteBuffer, boolean) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.decode.DecoderFactory
-
- checkOut(OutputStream, boolean) - Static method in class org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderFactory
-
- checkOut(OutputStream, boolean) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderPool
-
- checkOut(OutputStream, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.EncoderPoolImpl
-
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- checkOutputSpecs(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Checks if the output target exists.
- checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface
-
- checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest, RpcCallback<AccessControlProtos.CheckPermissionsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
-
rpc CheckPermissions(.CheckPermissionsRequest) returns (.CheckPermissionsResponse);
- checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest, RpcCallback<AccessControlProtos.CheckPermissionsResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Interface
-
rpc CheckPermissions(.CheckPermissionsRequest) returns (.CheckPermissionsResponse);
- checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest, RpcCallback<AccessControlProtos.CheckPermissionsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Stub
-
- checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest, RpcCallback<AccessControlProtos.CheckPermissionsResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- checkQuota(int, int, int) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- checkQuota(int, int, int) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Checks if it is possible to execute the specified operation.
- checkQuota(long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Checks if it is possible to execute the specified operation.
- checkQuota(Region, OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
Check the quota for the current (rpc-context) user.
- checkQuota(Region, List<ClientProtos.Action>) - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
Check the quota for the current (rpc-context) user.
- checkQuota(long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- checkQuotaToCreateTable(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
Check quota to create table.
- checkQuotaToSplitRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- checkQuotaToUpdateRegion(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
Check and update region count quota for an existing table.
- checkReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkReadsEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkRegionBoundaries() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- checkRegionChain(TableIntegrityErrorHandler) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
Check the region chain (from META) of this table.
- checkRegionDir(Path) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Check all column families in a region dir.
- checkReseek() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- checkScanOrder(Cell, Cell, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Check whether scan as expected order
- checkScanStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- checkScanStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
-
- checkShortCircuitReadBufferSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Check if short circuit read buffer size is set and if not, set it to hbase value.
- checkSnapshotSupport() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Throws an exception if snapshot operations (take a snapshot, restore, clone) are not supported.
- checkSplit() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Return the splitpoint.
- checkState(int) - Method in interface org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture.WaitForStateCallable
-
- CHECKSUM_TYPE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
The name of the configuration parameter that specifies
the name of an algorithm that is used to compute checksums
for newly created blocks.
- ChecksumFactory - Class in org.apache.hadoop.hbase.util
-
Utility class that is used to generate a Checksum object.
- ChecksumFactory() - Constructor for class org.apache.hadoop.hbase.util.ChecksumFactory
-
- checksumOk() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Report that checksum was ok, so we may ponder going back to HBase checksum.
- ChecksumType - Enum in org.apache.hadoop.hbase.util
-
Checksum types.
- ChecksumUtil - Class in org.apache.hadoop.hbase.io.hfile
-
Utility methods to compute and validate checksums.
- ChecksumUtil() - Constructor for class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
-
- checkTableLocks() - Method in class org.apache.hadoop.hbase.util.hbck.TableLockChecker
-
- checkTableModifiable(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- checkTableModifiable(TableName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Check table is modifiable; i.e.
- checkTableModifiable(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterDDLOperationHelper
-
Check whether a table is modifiable - exists and either offline or online with config set
- checkTables(Collection<Path>) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Check the specified table dirs for bad hfiles.
- checkTasks() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
tells Coordination that it should check for new tasks
- checkTasks() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- checkTaskStillAvailable(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Check that the task is still there
- checkTaskStillAvailable(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- checkThrowable(Throwable) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
-
Examine passed Throwable.
- checkTimestamps(Map<byte[], List<Cell>>, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- checkTimestamps(Map<byte[], List<Cell>>, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Check the collection of families for valid timestamps
- checkType(TMutation._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- checkValue(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Checks the given value for validity.
- checkVersion(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies current version of file system
- checkVersion(FileSystem, Path, boolean, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies current version of file system
- checkVersions(byte[], int, int, long, byte, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Keeps track of the number of versions for the columns asked for.
- checkVersions(byte[], int, int, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
- checkVersions(byte[], int, int, long, byte, boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
Keeps track of the number of versions for the columns asked for.
- checkZk() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
Try to create a Zookeeper connection.
- children - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- childrenCountDown() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor to notify that one of the sub-procedures
has completed.
- childZNode - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
- chore() - Method in class org.apache.hadoop.hbase.HealthCheckChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.balancer.BalancerChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.balancer.ClusterStatusChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
-
- chore() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.cleaner.ReplicationZKLockCleanerChore
-
- chore() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- chore() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionsCleaner
-
- chore() - Method in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
- chore() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
The task to execute on each scheduled execution of the Chore
- choreForTesting() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- ChoreService - Class in org.apache.hadoop.hbase
-
ChoreService is a service that can be used to schedule instances of
ScheduledChore
to run
periodically while sharing threads.
- ChoreService(String) - Constructor for class org.apache.hadoop.hbase.ChoreService
-
- ChoreService(String, int) - Constructor for class org.apache.hadoop.hbase.ChoreService
-
- Cipher - Class in org.apache.hadoop.hbase.io.crypto
-
A common interface for a cryptographic algorithm.
- Cipher(CipherProvider) - Constructor for class org.apache.hadoop.hbase.io.crypto.Cipher
-
- CIPHER_AES - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default cipher for encryption
- CIPHER_MODE_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- CIPHER_PROVIDER_KEY - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- CipherProvider - Interface in org.apache.hadoop.hbase.io.crypto
-
An CipherProvider contributes support for various cryptographic
Ciphers.
- claimQueues(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Take ownership for the set of queues belonging to a dead region server.
- claimQueues(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- CLASS_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- CLASS_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- Classes - Class in org.apache.hadoop.hbase.util
-
Utilities for class manipulation.
- Classes() - Constructor for class org.apache.hadoop.hbase.util.Classes
-
- classifyExs(List<Throwable>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- ClassLoaderBase - Class in org.apache.hadoop.hbase.util
-
Base class loader that defines couple shared constants used
by sub-classes.
- ClassLoaderBase(ClassLoader) - Constructor for class org.apache.hadoop.hbase.util.ClassLoaderBase
-
Creates a DynamicClassLoader that can load classes dynamically
from jar files under a specific folder.
- ClassSize - Class in org.apache.hadoop.hbase.util
-
Class for determining the "size" of a class, an attempt to calculate the
actual bytes that an object of this class will occupy in memory
The core of this class is taken from the Derby project
- ClassSize() - Constructor for class org.apache.hadoop.hbase.util.ClassSize
-
- clean(HRegionInfo) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
This method is used during rollback
- clean(HRegionInfo) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
-
clean the split transaction
- clean(HRegionInfo) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
- clean(HRegionInfo) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
-
- cleanAllPreviousInstances(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- CleanerChore<T extends FileCleanerDelegate> - Class in org.apache.hadoop.hbase.master.cleaner
-
Abstract Cleaner that uses a chain of delegates to clean a directory of files
- CleanerChore(String, int, Stoppable, Configuration, FileSystem, Path, String) - Constructor for class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- cleanersChain - Variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- cleanMergeQualifier(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
-
Checks if the specified region has merge qualifiers, if so, try to clean
them
- cleanMovedRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Remove the expired entries from the moved regions list.
- cleanOldLogs(String, String, boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Cleans a log file and all older files from ZK.
- cleanPreviousInstance(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
A dead server that comes back alive has a different start code.
- cleanup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- cleanup() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
Explicitly mark this status as able to be cleaned up,
even though it might not be complete.
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
-
Cancel threads if they haven't finished.
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
Users should override this method.
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- cleanup(Exception) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
Cancel threads if they haven't finished.
- cleanup() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
Override to run cleanup tasks when the Chore encounters an error and must stop running
- cleanupBulkLoad(String) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
-
- cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.BlockingInterface
-
- cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.CleanupBulkLoadResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
-
rpc CleanupBulkLoad(.CleanupBulkLoadRequest) returns (.CleanupBulkLoadResponse);
- cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.CleanupBulkLoadResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Interface
-
rpc CleanupBulkLoad(.CleanupBulkLoadRequest) returns (.CleanupBulkLoadResponse);
- cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.CleanupBulkLoadResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Stub
-
- cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, RpcCallback<SecureBulkLoadProtos.CleanupBulkLoadResponse>) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- cleanupCalls(boolean) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
-
Cleanup the calls older than a given timeout, in milli seconds.
- cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- clear() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
These methods are unsupported, and no code using CompoundConfiguration depend upon them.
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- clear() - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
-
- clear() - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
Flushes the dictionary, empties all values.
- clear() - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
-
- clear() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- clear() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureFairRunQueues
-
- clear() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
-
Removes all of the elements from this collection.
- clear() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
-
- clear() - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- clear() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Clears all entries from the map.
- clear() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- clear() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- clear() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- clear() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Removes all metrics about this Source.
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- clear() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- clear() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- clear() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- clear() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- clear() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- clear() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- clear() - Method in class org.apache.hadoop.hbase.util.BoundedConcurrentLinkedQueue
-
- clear() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- clear() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- clear() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- clear() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- clear() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- clear(Configuration) - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
Delete the master znode if its content (ServerName string) is the same
as the one in the znode file.
- clear() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Resets the estimator, clearing out all previously inserted items
- clearAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
repeated .Permission.Action action = 1;
- clearAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
repeated .Permission.Action action = 2;
- clearAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
repeated .Permission.Action action = 4;
- clearAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- clearAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
required .FlushDescriptor.FlushAction action = 1;
- clearAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
required uint64 ageOfLastAppliedOp = 1;
- clearAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint64 ageOfLastShippedOp = 2;
- clearAlgorithm() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required string algorithm = 1;
- clearAllowPartialResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool allow_partial_results = 18;
- clearArchive() - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
- clearAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
optional bool assign_seq_num = 3;
- clearAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
optional bool assign_seq_num = 2;
- clearAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
optional int32 associated_cell_count = 3;
- clearAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional int32 associated_cell_count = 8;
- clearAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional int32 associated_cell_count = 2;
- clearAtomic() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
optional bool atomic = 2;
- clearAttribute() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- clearAttribute() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- clearAttribute() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- clearAttributes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- clearAttributes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- clearAttrs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- clearAttrs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- clearAuth() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
repeated bytes auth = 2;
- clearAuth() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
repeated bytes auth = 2;
- clearAuth() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
repeated uint32 auth = 2;
- clearAuthMethod() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
optional string auth_method = 2;
- clearAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.BlockingInterface
-
- clearAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService
-
rpc clearAuths(.SetAuthsRequest) returns (.VisibilityLabelsResponse);
- clearAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.Interface
-
rpc clearAuths(.SetAuthsRequest) returns (.VisibilityLabelsResponse);
- clearAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.Stub
-
- clearAuths(byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- clearAuths(Configuration, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Removes given labels from user's globally authorized list of labels.
- clearAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- clearAuths(byte[], List<byte[]>) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Removes given labels from user's globally authorized list of labels.
- clearAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
optional double averageLoad = 5;
- clearBackupMasters() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- clearBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional bool balancer_on = 9;
- clearBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
-
optional bool balancer_on = 1;
- clearBalancerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
-
required bool balancer_ran = 1;
- clearBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int32 batch = 4;
- clearBatchSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 batch_size = 9;
- clearBigdecimalMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
-
required bytes bigdecimal_msg = 1;
- clearBitwiseOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
required .BitComparator.BitwiseOp bitwise_op = 2;
- clearBulkloadSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required int64 bulkload_seq_num = 4;
- clearBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
required string bulk_token = 1;
- clearBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
required string bulk_token = 1;
- clearBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required string bulk_token = 4;
- clearBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional bool bypass_globals = 6;
- clearBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
optional bool bypass_globals = 1 [default = false];
- clearCache() - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Delete all cached entries.
- clearCache(ServerName) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Delete all cached entries of a server.
- clearCache(TableName) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Delete all cached entries of a table.
- clearCache(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Delete a cached location, no matter what it is.
- clearCache(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Delete a cached location, no matter what it is.
- clearCache(TableName, byte[], ServerName) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Delete a cached location for a table, row and server
- clearCache(HRegionInfo) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Deletes the cached location of the region if necessary, based on some error from source.
- clearCache(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
- clearCache() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Clears the cache.
- clearCache() - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- clearCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional bool cache_blocks = 7 [default = true];
- clearCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool cache_blocks = 8 [default = true];
- clearCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional bool cacheBlocks = 11;
- clearCaches(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Clear any caches that pertain to server name sn
.
- clearCaches(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
internal method, do not use thru HConnection
- clearCaching() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 caching = 17;
- clearCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int32 caching = 9;
- clearCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .CoprocessorServiceCall call = 2;
- clearCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional uint32 call_id = 1;
- clearCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional uint32 call_id = 1;
- clearCell() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- clearCellBlockCodecClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string cell_block_codec_class = 3;
- clearCellBlockCompressorClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string cell_block_compressor_class = 4;
- clearCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 5;
- clearCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 3;
- clearCellCodecClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional string cell_codec_cls_name = 5;
- clearCellsPerResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated uint32 cells_per_result = 1;
- clearCellType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional .CellType cell_type = 5;
- clearChance() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
-
required float chance = 1;
- clearCharset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required string charset = 3;
- clearChildZNodes() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- clearClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional string class_name = 1;
- clearClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required string class_name = 1;
- clearClientHandlesHeartbeats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool client_handles_heartbeats = 8;
- clearClientHandlesPartials() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool client_handles_partials = 7;
- clearClosed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
-
required bool closed = 1;
- clearCloseScanner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool close_scanner = 5;
- clearClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional bool closest_row_before = 11 [default = false];
- clearClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
required string cluster_id = 1;
- clearClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ClusterId cluster_id = 5;
- clearClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
Deprecated.
- clearClusterIds() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- clearClusterkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
required string clusterkey = 1;
- clearClusterStatus() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
required .ClusterStatus cluster_status = 1;
- clearColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- clearColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- clearColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional bytes column = 2;
- clearColumnBuffer() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
-
- clearColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- clearColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- clearColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- clearColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
optional bytes column_family = 2;
- clearColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bytes column_family = 1;
- clearColumnfamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required bytes columnfamily_name = 3;
- clearColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- clearColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- clearColumnName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
required bytes column_name = 2;
- clearColumnOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
optional bytes column_offset = 3;
- clearColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
optional bytes column_qualifier = 3;
- clearColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bytes column_qualifier = 2;
- clearColumns() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated bytes columns = 3;
- clearColumns() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- clearColumnValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- clearCompactionInput() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_input = 4;
- clearCompactionOutput() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_output = 5;
- clearCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
optional bool compaction_state = 2;
- clearCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
optional .GetRegionInfoResponse.CompactionState compaction_state = 2;
- clearCompactionTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
-
required int64 compaction_timestamp = 1;
- clearComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- clearComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- clearComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- clearComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- clearComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required .Comparator comparator = 5;
- clearComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
optional .Comparator comparator = 2;
- clearComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
required .Comparator comparator = 4;
- clearComparatorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional string comparator_class_name = 11;
- clearCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
required .CompareFilter compare_filter = 1;
- clearCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
required .CompareFilter compare_filter = 1;
- clearCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
required .CompareFilter compare_filter = 1;
- clearCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
required .CompareFilter compare_filter = 1;
- clearCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
required .CompareFilter compare_filter = 1;
- clearCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
required .CompareType compare_op = 1;
- clearCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
required .CompareType compare_op = 3;
- clearCompareType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required .CompareType compare_type = 4;
- clearCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 complete_sequence_id = 15;
- clearCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional string compression = 5;
- clearCompressionCodec() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 compression_codec = 12;
- clearCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
optional .Condition condition = 3;
- clearCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
optional .Condition condition = 3;
- clearConfiguration() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- clearConfiguration() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- clearConfiguration() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- clearConfiguration() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- clearConfiguration() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- clearConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .Consistency consistency = 12 [default = STRONG];
- clearConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .Consistency consistency = 16 [default = STRONG];
- clearCoprocessors() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- clearCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
-
required int64 count = 1 [default = 0];
- clearCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required uint64 create_time = 3;
- clearCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional int64 create_time = 6;
- clearCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
optional int64 creation_time = 3 [default = 0];
- clearCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional int64 creation_time = 3 [default = 0];
- clearCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 current_compacted_KVs = 11;
- clearCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 currentCompactedKVs = 13;
- clearData() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required bytes data = 3;
- clearData() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- clearData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional bytes data = 4;
- clearDataIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 data_index_count = 5;
- clearDataLocality() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional float data_locality = 16;
- clearDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string date = 5;
- clearDeadNodes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated string deadNodes = 2;
- clearDeadServers() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- clearDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string declaring_class = 1;
- clearDeleteColumnFamilyInModify() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required bool delete_column_family_in_modify = 4;
- clearDeleted() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 deleted = 3;
- clearDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required .BulkDeleteRequest.DeleteType deleteType = 2;
- clearDeleteType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional .MutationProto.DeleteType delete_type = 4;
- clearDestinationServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional .ServerName destination_server = 4;
- clearDestServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
optional .ServerName dest_server_name = 2;
- clearDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
optional bool done = 1 [default = false];
- clearDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
-
optional bool done = 1 [default = false];
- clearDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
optional bool done = 1 [default = false];
- clearDoNotRetry() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional bool do_not_retry = 5;
- clearDoubleMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
-
required double double_msg = 1;
- clearDropDependentColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
optional bool drop_dependent_column = 4;
- clearDurability() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .MutationProto.Durability durability = 6 [default = USE_DEFAULT];
- clearEffectiveUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
required string effective_user = 1;
- clearEnable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
-
required bool enable = 1;
- clearEnabled() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
-
required bool enabled = 1;
- clearEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required bytes encoded_region_name = 2;
- clearEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required bytes encoded_region_name = 2;
- clearEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
required bytes encoded_region_name = 3;
- clearEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
required bytes encoded_region_name = 3;
- clearEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required bytes encoded_region_name = 1;
- clearEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional bytes encryption_key = 13;
- clearEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional bytes encryption_key = 2;
- clearEndKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bytes end_key = 4;
- clearEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional bytes endKey = 3;
- clearEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional bytes endRow = 2;
- clearEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int64 endTime = 6;
- clearEngine() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
optional string engine = 4;
- clearEntry() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- clearEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 entry_count = 7;
- clearErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional bytes error_info = 3;
- clearErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
optional string error_message = 1;
- clearErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required string error_message = 2;
- clearEventType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
required .RegionEventDescriptor.EventType event_type = 1;
- clearEventTypeCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required uint32 event_type_code = 1;
- clearException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
optional .NameBytesPair exception = 2;
- clearException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .NameBytesPair exception = 3;
- clearException() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional .ForeignExceptionMessage exception = 5;
- clearException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional .ForeignExceptionMessage exception = 10;
- clearException() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .ExceptionResponse exception = 2;
- clearExceptionClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string exception_class_name = 1;
- clearExecuted() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
-
required bool executed = 1;
- clearExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional bool existence_only = 10 [default = false];
- clearExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional bool exists = 3;
- clearExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
optional int64 expected_timeout = 1;
- clearExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
-
required int64 expected_timeout = 1;
- clearExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
required int64 expiration_date = 2;
- clearExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
optional int64 expiration_date = 5;
- clearExpression() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
required string expression = 1;
- clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional bytes family = 2;
- clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
optional bytes family = 3;
- clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
repeated bytes family = 2;
- clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes family = 2;
- clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
required bytes family = 2;
- clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
required bytes family = 1;
- clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
required bytes family = 1;
- clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required bytes family = 2;
- clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
required bytes family = 1;
- clearFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
required bytes family = 1;
- clearFamilyFiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- clearFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
required bytes family_name = 1;
- clearFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
required bytes family_name = 1;
- clearFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required bytes family_name = 3;
- clearFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
required bytes family_name = 1;
- clearFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
required bytes family_name = 1;
- clearFamilyPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- clearFamilyPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- clearFavoredNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- clearFavoredNodes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- clearFavoredNodes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- clearFileInfoOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 file_info_offset = 1;
- clearFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string file_name = 3;
- clearFiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Clears all the files currently in use and returns them.
- clearFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- clearFileSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
optional uint64 file_size = 3;
- clearFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .Filter filter = 4;
- clearFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .Filter filter = 5;
- clearFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
required .Filter filter = 1;
- clearFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
required .Filter filter = 1;
- clearFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
required .Filter filter = 1;
- clearFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional string filter = 8;
- clearFilterIfMissing() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bool filter_if_missing = 5;
- clearFilters() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- clearFirst() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
required bytes first = 1;
- clearFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 first_data_block_offset = 9;
- clearFirstPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
repeated bytes first_part = 1;
- clearFlushed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
optional bool flushed = 2;
- clearFlushOutput() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
repeated string flush_output = 3;
- clearFlushSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
optional uint64 flush_sequence_number = 4;
- clearFollowingKvCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint32 following_kv_count = 7;
- clearForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
optional bool force = 2 [default = false];
- clearForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
optional bool forcible = 3 [default = false];
- clearForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
optional bool forcible = 3 [default = false];
- clearFrom() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
optional uint64 from = 1;
- clearFsToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required .DelegationToken fs_token = 3;
- clearFuzzyKeysData() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- clearGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional .GenericExceptionMessage generic_exception = 2;
- clearGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .Get get = 3;
- clearGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .Get get = 2;
- clearGlobalPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .GlobalPermission global_permission = 2;
- clearHasCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional bool has_compression = 1;
- clearHash() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
optional bytes hash = 5;
- clearHashCache() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- clearHasTagCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional bool has_tag_compression = 3;
- clearHbaseVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .HBaseVersionFileContent hbase_version = 1;
- clearHeapOccupancy() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
optional int32 heapOccupancy = 2 [default = 0];
- clearHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int32 heapSizeMB = 4;
- clearHeartbeatMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool heartbeat_message = 9;
- clearHfile() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string hfile = 3;
- clearHostName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
required string host_name = 1;
- clearHostname() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string hostname = 3;
- clearId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
required int32 id = 1;
- clearId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional int64 id = 4;
- clearIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
optional bytes identifier = 1;
- clearIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional bytes identifier = 1;
- clearIfOlderThanTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
optional uint64 if_older_than_ts = 2;
- clearIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional bool include_sys_tables = 3 [default = false];
- clearIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional bool include_sys_tables = 2 [default = false];
- clearIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional uint32 index = 1;
- clearIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional uint32 index = 1;
- clearInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
optional int32 infoPort = 1;
- clearInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
optional uint32 info_port = 3;
- clearInfoServerPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint32 info_server_port = 9;
- clearInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional bool inMemory = 4;
- clearInstance() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
optional string instance = 2;
- clearInterpreterClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required string interpreter_class_name = 1;
- clearInterpreterSpecificBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
optional bytes interpreter_specific_bytes = 3;
- clearIsMasterRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
-
required bool is_master_running = 1;
- clearIsProcedureAborted() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
-
required bool is_procedure_aborted = 1;
- clearIsRecovering() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
optional bool isRecovering = 3;
- clearIsShared() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional bool is_shared = 4;
- clearIssueDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
optional int64 issue_date = 4;
- clearIv() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
optional bytes iv = 4;
- clearJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string jerseyVersion = 5;
- clearJmxCache() - Static method in class org.apache.hadoop.metrics2.impl.JmxCacheBuster
-
For JMX to forget about all previously exported metrics.
- clearJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string jvmVersion = 2;
- clearKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
required .WALKey key = 1;
- clearKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
required bytes key = 3;
- clearKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
required bytes key = 1;
- clearKeyId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
required int32 key_id = 3;
- clearKeyType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional .CellType key_type = 5;
- clearKeyValueBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
repeated bytes key_value_bytes = 2;
- clearKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
required .TokenIdentifier.Kind kind = 1;
- clearKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional string kind = 3;
- clearLabel() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
repeated string label = 1;
- clearLabel() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
repeated bytes label = 1;
- clearLabel() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
required bytes label = 1;
- clearLabels() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated string labels = 10;
- clearLastAssignment(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- clearLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 last_data_block_offset = 10;
- clearLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
required uint64 last_flushed_sequence_id = 1;
- clearLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
required uint64 last_flushed_sequence_id = 1;
- clearLastFlushTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
required uint64 last_flush_time = 1;
- clearLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 last_major_compaction_ts = 17 [default = 0];
- clearLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional uint64 last_update = 3;
- clearLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required uint64 last_update = 8;
- clearLatestVersionOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bool latest_version_only = 6;
- clearLeastSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
required uint64 least_sig_bits = 1;
- clearLenAsVal() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
-
required bool len_as_val = 1;
- clearLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required uint32 length = 2;
- clearLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
-
optional uint32 length = 1;
- clearLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
-
required int32 limit = 1;
- clearLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
required int32 limit = 1;
- clearLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional int32 line_number = 4;
- clearLiveNodes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- clearLiveServers() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- clearLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
optional .ServerLoad load = 2;
- clearLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool load_column_families_on_demand = 13;
- clearLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
-
required bool loaded = 1;
- clearLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
-
required bool loaded = 1;
- clearLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 load_on_open_data_offset = 2;
- clearLoadStats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .RegionLoadStats loadStats = 5;
- clearLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional string location = 5;
- clearLocations() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
repeated string locations = 2;
- clearLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
required string lock_owner = 1;
- clearLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .ServerName lock_owner = 2;
- clearLogId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint64 log_id = 3;
- clearLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional uint64 log_sequence_number = 4;
- clearLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required uint64 log_sequence_number = 3;
- clearLongMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
-
required int64 long_msg = 1;
- clearMajor() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
optional bool major = 2;
- clearMapEntries() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- clearMapEntry() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- clearMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ServerName master = 7;
- clearMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
required .ServerName master = 1;
- clearMasterCoprocessors() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- clearMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
optional uint64 master_system_time = 4;
- clearMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
optional uint64 master_system_time = 5;
- clearMaxColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bytes max_column = 3;
- clearMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bool max_column_inclusive = 4;
- clearMaxHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint32 max_heap_MB = 4;
- clearMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int32 maxHeapSizeMB = 5;
- clearMaxResultSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint64 max_result_size = 10;
- clearMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional uint32 max_versions = 6 [default = 1];
- clearMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 max_versions = 7 [default = 1];
- clearMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional int32 maxVersions = 4;
- clearMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int32 maxVersions = 7;
- clearMayInterruptIfRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
optional bool mayInterruptIfRunning = 2 [default = true];
- clearMemstoreLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
optional int32 memstoreLoad = 1 [default = 0];
- clearMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 memstore_size_MB = 6;
- clearMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 memstoreSizeMB = 5;
- clearMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional string message = 2;
- clearMetaIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 meta_index_count = 6;
- clearMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required string method_name = 3;
- clearMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string method_name = 2;
- clearMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional string method_name = 3;
- clearMetrics() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- clearMetrics() - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- clearMinColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bytes min_column = 1;
- clearMinColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bool min_column_inclusive = 2;
- clearMinProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint64 min_proc_id = 4;
- clearMode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN];
- clearModifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .TableSchema modified_table_schema = 3;
- clearMoreResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool more_results = 3;
- clearMoreResultsInRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool more_results_in_region = 8;
- clearMostSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
required uint64 most_sig_bits = 2;
- clearMutateType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .MutationProto.MutationType mutate_type = 2;
- clearMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .MutationProto mutation = 2;
- clearMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .MutationProto mutation = 2;
- clearMutationRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
required string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
required string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
required bytes name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
required string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
required string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
optional string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
required bytes name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
required string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
required string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
required string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
required string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
required string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
required bytes name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
required string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
required string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
repeated string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
required string name = 1;
- clearName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional string name = 1;
- clearNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
required bytes namespace = 1;
- clearNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional string namespace = 4;
- clearNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional string namespace = 3;
- clearNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string namespace = 3;
- clearNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- clearNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- clearNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- clearNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- clearNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional bytes namespace_name = 3;
- clearNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
optional bytes namespace_name = 1;
- clearNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
required string namespaceName = 1;
- clearNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
required string namespaceName = 1;
- clearNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
required string namespaceName = 1;
- clearNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
required string namespaceName = 1;
- clearNamespacePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .NamespacePermission namespace_permission = 3;
- clearNextCallSeq() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional uint64 next_call_seq = 6;
- clearNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional uint64 nonce = 9;
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
optional uint64 nonce = 3 [default = 0];
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
optional uint64 nonce = 3 [default = 0];
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
optional uint64 nonce = 3 [default = 0];
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
optional uint64 nonce = 3;
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint64 nonce = 14 [default = 0];
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional uint64 nonce = 5;
- clearNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint64 nonce = 10;
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
optional uint64 nonceGroup = 2;
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
optional uint64 nonce_group = 4;
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
optional uint64 nonce_group = 2 [default = 0];
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
optional uint64 nonce_group = 2 [default = 0];
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
optional uint64 nonce_group = 2 [default = 0];
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
optional uint64 nonce_group = 2;
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint64 nonce_group = 13 [default = 0];
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional uint64 nonce_group = 4;
- clearNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint64 nonceGroup = 9;
- clearNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 number_of_requests = 1;
- clearNumberOfRows() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional uint32 number_of_rows = 4;
- clearNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 num_data_index_levels = 8;
- clearOffline() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bool offline = 5;
- clearOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
optional int32 offset = 2;
- clearOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
required bool on = 1;
- clearOpenForDistributedLogReplay() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
optional bool openForDistributedLogReplay = 4;
- clearOpenInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- clearOpeningState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- clearOpenSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
optional uint64 open_seq_num = 3;
- clearOperator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
required .FilterList.Operator operator = 1;
- clearOrdinal() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
optional uint32 ordinal = 2;
- clearOrigSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint64 orig_sequence_number = 11;
- clearOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string osVersion = 3;
- clearOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional string owner = 6;
- clearOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional string owner = 5;
- clearPageSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
-
required int64 page_size = 1;
- clearParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint64 parent_id = 2;
- clearParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
optional int64 parent_id = 2;
- clearPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional bool partial = 5 [default = false];
- clearPartialFlagPerResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated bool partial_flag_per_result = 7;
- clearPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
optional bytes password = 2;
- clearPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional bytes password = 2;
- clearPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
required string path = 2;
- clearPattern() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required string pattern = 1;
- clearPatternFlags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required int32 pattern_flags = 2;
- clearPayload() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
optional bytes payload = 5;
- clearPeerID() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required string peerID = 1;
- clearPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- clearPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
required .Permission permission = 3;
- clearPermissions() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- clearPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
optional uint32 port = 2;
- clearPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
required uint32 port = 1;
- clearPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional int32 port = 4;
- clearPosition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
-
required int64 position = 1;
- clearPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
-
required bytes prefix = 1;
- clearPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
-
optional bytes prefix = 1;
- clearPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
required bool preserve_splits = 2;
- clearPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
optional bool preserveSplits = 2 [default = false];
- clearPrevBalanceValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
-
optional bool prev_balance_value = 1;
- clearPrevValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
-
optional bool prev_value = 1;
- clearPriority() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional uint32 priority = 6;
- clearProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
required .ProcedureDescription procedure = 1;
- clearProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
optional .ProcedureDescription procedure = 1;
- clearProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- clearProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- clearProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
optional bool processed = 2;
- clearProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
optional bool processed = 2;
- clearProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
required uint64 proc_id = 1;
- clearProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
-
optional uint64 proc_id = 1;
- clearProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
-
optional uint64 proc_id = 1;
- clearProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
-
optional uint64 proc_id = 1;
- clearProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
-
optional uint64 proc_id = 1;
- clearProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
-
required uint64 proc_id = 1;
- clearProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required uint64 proc_id = 3;
- clearProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
optional uint64 proc_id = 3;
- clearPurpose() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional string purpose = 5;
- clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional bytes qualifier = 3;
- clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes qualifier = 3;
- clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
required bytes qualifier = 3;
- clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
repeated bytes qualifier = 2;
- clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required bytes qualifier = 3;
- clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional bytes qualifier = 1;
- clearQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
required bytes qualifier = 2;
- clearQualifiers() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
repeated bytes qualifiers = 1;
- clearQualifierValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- clearRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
required .Reference.Range range = 2;
- clearReadNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_num = 5;
- clearReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional bool readOnly = 5;
- clearReadRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 read_requests_count = 8;
- clearReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 readRequestsCount = 7;
- clearReadSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_size = 6;
- clearRealUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
optional string real_user = 2;
- clearReason() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
required string reason = 1;
- clearReference() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
optional .Reference reference = 2;
- clearRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional string regex = 2;
- clearRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional string regex = 1;
- clearRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
optional string regex = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
required .RegionInfo region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
required .RegionInfo region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .RegionInfo region = 4;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- clearRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- clearRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- clearRegionAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- clearRegionActionResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- clearRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- clearRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Allows flushing the region cache.
- clearRegionCache(TableName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Allows flushing the region cache of all locations that pertain to
tableName
- clearRegionCache() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
internal method, do not use thru HConnection
- clearRegionCache(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
internal method, do not use thru HConnection
- clearRegionCache(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- clearRegionCache() - Method in class org.apache.hadoop.hbase.client.HTable
-
Explicitly clears the region cache to fetch the latest value from META.
- clearRegionId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
required uint64 region_id = 1;
- clearRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- clearRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
required .RegionInfo region_info = 1;
- clearRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
required .RegionInfo regionInfo = 1;
- clearRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
required .RegionInfo region_info = 1;
- clearRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- clearRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- clearRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- clearRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- clearRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
required .RegionInfo region_info = 2;
- clearRegionLoads() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- clearRegionManifests() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- clearRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
-
required bytes region_name = 1;
- clearRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
optional bytes region_name = 7;
- clearRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
optional bytes region_name = 6;
- clearRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional bytes region_name = 7;
- clearRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required bytes region_name = 2;
- clearRegionReplayEditsSize(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Clear a region from replayEditsPerRegion.
- clearRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
optional int32 regions = 3;
- clearRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- clearRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- clearRegionsInTransition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- clearRegionSpecifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
required .RegionSpecifier region_specifier = 1;
- clearRegionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionState region_state = 2;
- clearRegionToFlush() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
repeated bytes region_to_flush = 1;
- clearRemoveAll() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional bool remove_all = 5;
- clearRenew() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool renew = 10 [default = false];
- clearReplicaId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional int32 replica_id = 7 [default = 0];
- clearReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
optional string replicationEndpointImpl = 2;
- clearReplicationLag() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint64 replicationLag = 5;
- clearReplLoadSink() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional .ReplicationLoadSink replLoadSink = 11;
- clearReplLoadSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- clearReportEndTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 report_end_time = 8;
- clearReportStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 report_start_time = 7;
- clearReqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_num = 1;
- clearReqSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_size = 2;
- clearRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required bytes request = 4;
- clearRequestParam() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional bool request_param = 4;
- clearRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
optional int64 requests = 4;
- clearRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int64 requests = 3;
- clearResponse() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
-
optional uint32 response = 1;
- clearRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string restVersion = 1;
- clearResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
optional .Result result = 1;
- clearResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
optional .Result result = 1;
- clearResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .Result result = 2;
- clearResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional bytes result = 4;
- clearResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional bytes result = 11;
- clearResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- clearResultOrException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- clearResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- clearReturnData() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
optional bytes return_data = 2;
- clearReversed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool reversed = 15 [default = false];
- clearRevision() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string revision = 3;
- clearRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 root_index_size_KB = 12;
- clearRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 rootIndexSizeKB = 9;
- clearRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes row = 1;
- clearRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
required bytes row = 1;
- clearRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required bytes row = 1;
- clearRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required bytes row = 1;
- clearRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
required bytes row = 1;
- clearRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional bytes row = 1;
- clearRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional bytes row = 1;
- clearRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required uint32 rowBatchSize = 4;
- clearRowProcessorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
required string row_processor_class_name = 1;
- clearRowProcessorInitializerMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional bytes row_processor_initializer_message = 3;
- clearRowProcessorInitializerMessageName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional string row_processor_initializer_message_name = 2;
- clearRowProcessorResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
-
required bytes row_processor_result = 1;
- clearRowRangeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- clearRows() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- clearRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
required uint64 rowsDeleted = 1;
- clearRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
optional uint32 rpc_version = 2;
- clearRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
optional uint32 rpc_version = 2;
- clearScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required .Scan scan = 1;
- clearScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required .Scan scan = 2;
- clearScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .Scan scan = 2;
- clearScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional uint64 scanner_id = 3;
- clearScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional uint64 scanner_id = 2;
- clearScanResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
-
optional int32 scan_result = 1;
- clearScope() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
optional .QuotaScope scope = 4 [default = MACHINE];
- clearScopes() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- clearScopeType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
required .ScopeType scope_type = 2;
- clearSecond() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
required bytes second = 2;
- clearSecondPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
optional bytes second_part = 2;
- clearSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
required uint64 sequence_id = 2;
- clearSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
optional int64 sequence_number = 6;
- clearSerializedComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
optional bytes serialized_comparator = 2;
- clearSerializedFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
optional bytes serialized_filter = 2;
- clearServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerName server = 1;
- clearServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
required .ServerName server = 1;
- clearServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
required .ServerName server = 1;
- clearServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required .ServerName server = 1;
- clearServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional .ServerName server = 6;
- clearServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
required .ServerName server = 1;
- clearServerCurrentTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
required uint64 server_current_time = 3;
- clearServerInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
required .ServerInfo server_info = 1;
- clearServerLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerLoad server_load = 2;
- clearServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
required .ServerName server_name = 1;
- clearServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required .ServerName server_name = 4;
- clearServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
required .ServerName server_name = 2;
- clearServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional uint64 serverStartCode = 5;
- clearServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
optional uint64 serverStartCode = 2;
- clearServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
required uint64 server_start_code = 2;
- clearServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string serverVersion = 4;
- clearService() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
optional bytes service = 3;
- clearService() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional string service = 4;
- clearServiceCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .CoprocessorServiceCall service_call = 4;
- clearServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required string service_name = 2;
- clearServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string service_name = 2;
- clearServiceResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .CoprocessorServiceResult service_result = 4;
- clearShare() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
optional float share = 3;
- clearSignature() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
required string signature = 1;
- clearSingleColumnValueFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- clearSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint32 sizeOfLogQueue = 3;
- clearSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required bool skip_table_state_check = 3;
- clearSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required bool skip_table_state_check = 3;
- clearSmall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool small = 14;
- clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
optional .ProcedureDescription snapshot = 2;
- clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
optional .SnapshotDescription snapshot = 2;
- clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- clearSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- clearSnapshot(long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
The passed snapshot was successfully persisted; it can be let go.
- clearSnapshot(long) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Clears the current snapshot of the Memstore.
- clearSnapshots() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- clearSoftLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
optional uint64 soft_limit = 2;
- clearSortedPrefixes() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
repeated bytes sorted_prefixes = 1;
- clearSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional string source = 1;
- clearSpec() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionSpecifier spec = 1;
- clearSplit() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bool split = 6;
- clearSplitkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
required bytes splitkey = 1;
- clearSplitKeys() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
repeated bytes split_keys = 2;
- clearSplitPoint() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
optional bytes split_point = 2;
- clearSrcChecksum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string src_checksum = 6;
- clearStackId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
repeated uint32 stack_id = 7;
- clearStackTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string stack_trace = 2;
- clearStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional bool stale = 4 [default = false];
- clearStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool stale = 6;
- clearStamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
optional uint64 stamp = 3;
- clearStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
optional uint64 start_code = 3;
- clearStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int64 startCode = 2;
- clearStartDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
required string start_date = 1;
- clearStartId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
required uint64 start_id = 1;
- clearStartKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bytes start_key = 3;
- clearStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional bytes startKey = 2;
- clearStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bytes start_row = 3;
- clearStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bytes start_row = 1;
- clearStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional bytes startRow = 1;
- clearStartRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bool start_row_inclusive = 2;
- clearStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional uint64 start_time = 2;
- clearStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required uint64 start_time = 4;
- clearStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int64 startTime = 5;
- clearState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
required .RegionState.State state = 2;
- clearState() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
required .GetProcedureResultResponse.State state = 1;
- clearState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required .ProcedureState state = 6;
- clearState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
repeated uint32 state = 1;
- clearState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
optional .RegionState.State state = 3;
- clearState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
-
required .ReplicationState.State state = 1;
- clearState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
required .SplitLogTask.State state = 1;
- clearState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
-
required .Table.State state = 1 [default = ENABLED];
- clearStateData() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional bytes state_data = 12;
- clearStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bytes stop_row = 4;
- clearStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bytes stop_row = 3;
- clearStopRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bool stop_row_inclusive = 4;
- clearStopRowKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
-
optional bytes stop_row_key = 1;
- clearStoreCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- clearStoreFile() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
repeated string store_file = 1;
- clearStoreFile() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
repeated string store_file = 3;
- clearStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 storefile_index_size_MB = 7;
- clearStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 storefileIndexSizeMB = 6;
- clearStorefiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 storefiles = 3;
- clearStoreFiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- clearStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 storefiles = 3;
- clearStorefileSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 storefile_size_MB = 5;
- clearStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 storefileSizeMB = 4;
- clearStoreFlushes() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- clearStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required string store_home_dir = 6;
- clearStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
required string store_home_dir = 2;
- clearStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
required string store_home_dir = 2;
- clearStoreLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- clearStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional uint32 store_limit = 8;
- clearStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 store_limit = 11;
- clearStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional uint32 store_offset = 9;
- clearStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 store_offset = 12;
- clearStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 stores = 2;
- clearStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- clearStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- clearStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 stores = 2;
- clearStoreSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- clearStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 store_uncompressed_size_MB = 4;
- clearSubstr() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
required string substr = 1;
- clearSynchronous() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
optional bool synchronous = 2;
- clearTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional string table = 2;
- clearTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .TableSchema table = 3;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional .TableName table_name = 2;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
required .TableName table_name = 2;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
optional .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .TableName table_name = 2;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .TableName table_name = 2;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .TableName table_name = 2;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableName table_name = 3;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
required .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
required .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
required .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
required .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
required .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
required .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .TableName table_name = 4;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
required .TableName tableName = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
required .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required .TableName table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required bytes table_name = 1;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
required bytes table_name = 2;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
required bytes table_name = 2;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required bytes table_name = 2;
- clearTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .TableName table_name = 1;
- clearTableNames() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- clearTableNames() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- clearTablePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .TablePermission table_permission = 4;
- clearTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .TableSchema table_schema = 2;
- clearTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableSchema table_schema = 4;
- clearTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
required .TableSchema table_schema = 1;
- clearTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- clearTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- clearTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableSchema table_schema = 2;
- clearTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
required .TableSchema table_schema = 1;
- clearTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes tags = 7;
- clearTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional bytes tags = 7;
- clearTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional bytes tags = 5;
- clearThreadId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional int64 thread_id = 3;
- clearThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .ThrottleRequest throttle = 7;
- clearThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
optional .Throttle throttle = 2;
- clearTimedQuota() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
optional .TimedQuota timed_quota = 2;
- clearTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint32 timeout = 9;
- clearTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .TimeRange time_range = 5;
- clearTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .TimeRange time_range = 7;
- clearTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .TimeRange time_range = 6;
- clearTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
optional uint64 timestamp = 3;
- clearTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional uint64 timestamp = 4;
- clearTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional uint64 timestamp = 4;
- clearTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional uint64 timestamp = 4;
- clearTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional uint64 timestamp = 3;
- clearTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional int64 timestamp = 3;
- clearTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint64 timeStampOfLastShippedOp = 4;
- clearTimestamps() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
repeated int64 timestamps = 1 [packed = true];
- clearTimeStampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
required uint64 timeStampsOfLastAppliedOp = 2;
- clearTimeUnit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
required .TimeUnit time_unit = 1;
- clearTo() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
optional uint64 to = 2;
- clearToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
optional .Token token = 1;
- clearTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 total_compacting_KVs = 10;
- clearTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 totalCompactingKVs = 12;
- clearTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 total_number_of_requests = 2;
- clearTotalRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
optional uint32 total_regions = 2;
- clearTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 total_static_bloom_size_KB = 14;
- clearTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 totalStaticBloomSizeKB = 11;
- clearTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 total_static_index_size_KB = 13;
- clearTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 totalStaticIndexSizeKB = 10;
- clearTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 total_uncompressed_bytes = 4;
- clearTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- clearTraceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
optional int64 trace_id = 1;
- clearTraceInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .RPCTInfo trace_info = 2;
- clearTrackerPos() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
required uint64 tracker_pos = 2;
- clearTransition() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- clearTransitionCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
required .RegionStateTransition.TransitionCode transition_code = 1;
- clearTransitionInZK() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional bool transition_in_ZK = 3 [default = true];
- clearTtl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional uint32 ttl = 4;
- clearTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional int32 ttl = 3;
- clearType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional .Permission.Type type = 1;
- clearType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
required .Permission.Type type = 1;
- clearType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
required .RegionSpecifier.RegionSpecifierType type = 1;
- clearType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional .SnapshotDescription.Type type = 4 [default = FLUSH];
- clearType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
required .ProcedureWALEntry.Type type = 1;
- clearType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint32 type = 2;
- clearType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
optional .ThrottleType type = 1;
- clearType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
required .SnapshotFileInfo.Type type = 1;
- clearUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 uncompressed_data_index_size = 3;
- clearUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- clearUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- clearUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- clearUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
optional .TableSchema unmodified_table_schema = 2;
- clearUpdated() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 updated = 2;
- clearUpdateInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- clearUrl() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string url = 2;
- clearUsedHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint32 used_heap_MB = 3;
- clearUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
required bytes user = 1;
- clearUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
required bytes user = 1;
- clearUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string user = 4;
- clearUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
-
required bytes user = 1;
- clearUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
required bytes user = 1;
- clearUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
required bytes user = 1;
- clearUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
required bytes user = 1;
- clearUserAuths() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- clearUserGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string user_group = 2;
- clearUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- clearUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .UserInformation user_info = 1;
- clearUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- clearUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .UserInformation user_info = 1;
- clearUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .UserInformation user_info = 1;
- clearUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .UserInformation user_info = 1;
- clearUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- clearUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .UserInformation user_info = 1;
- clearUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
required .UserInformation user_info = 1;
- clearUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .UserInformation user_info = 1;
- clearUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
required bytes username = 2;
- clearUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
optional string username = 1;
- clearUserName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string user_name = 1;
- clearUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- clearUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
required .UserPermission user_permission = 1;
- clearUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
required .UserPermission user_permission = 1;
- clearUserPermissions() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- clearUseThisHostnameInstead() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
optional string use_this_hostname_instead = 4;
- clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes value = 6;
- clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional bytes value = 6;
- clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .NameBytesPair value = 2;
- clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
optional .NameBytesPair value = 1;
- clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional bytes value = 2;
- clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
-
optional bytes value = 1;
- clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
optional bytes value = 2;
- clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
optional int64 value = 2;
- clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
required string value = 2;
- clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
required bytes value = 2;
- clearValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
-
required bool value = 1;
- clearValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
required string value = 2;
- clearValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
required string value = 2;
- clearValues() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- clearVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
required string version = 1;
- clearVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional int32 version = 5;
- clearVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint32 version = 1;
- clearVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
required uint32 version = 1;
- clearVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string version = 1;
- clearVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
optional int32 version = 1;
- clearVersionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .VersionInfo version_info = 5;
- clearVersionOfClosingNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional uint32 version_of_closing_node = 2;
- clearVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
optional uint32 version_of_offline_node = 2;
- clearVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
optional uint64 versionsDeleted = 2;
- clearVisLabel() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- clearWalName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string wal_name = 5;
- clearWalServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string wal_server = 4;
- clearWebuiPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
optional uint32 webui_port = 2;
- clearWriteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
optional bool write_flush_wal_marker = 3;
- clearWriteNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_num = 3;
- clearWriterClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional string writer_cls_name = 4;
- clearWriteRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 write_requests_count = 9;
- clearWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 writeRequestsCount = 8;
- clearWriteSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_size = 4;
- clearWriteTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required uint64 write_time = 4;
- clearWroteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
optional bool wrote_flush_wal_marker = 3;
- clearYetToUpdateRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
optional uint32 yet_to_update_regions = 1;
- clearZNodes(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- Client - Class in org.apache.hadoop.hbase.rest.client
-
A wrapper around HttpClient which provides some useful function and
semantics for interacting with the REST gateway.
- Client() - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Default Constructor
- Client(Cluster) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor
- Client(Cluster, boolean) - Constructor for class org.apache.hadoop.hbase.rest.client.Client
-
Constructor
- CLIENT_HANDLES_HEARTBEATS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- CLIENT_HANDLES_PARTIALS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- CLIENT_MAX_THREADS - Static variable in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
-
- CLIENT_PORT_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The ZK client port key in the ZK properties map.
- ClientBackoffPolicy - Interface in org.apache.hadoop.hbase.client.backoff
-
Configurable policy for the amount of time a client should wait for a new request to the
server when given the server load statistics.
- ClientBackoffPolicyFactory - Class in org.apache.hadoop.hbase.client.backoff
-
- ClientBackoffPolicyFactory.NoBackoffPolicy - Class in org.apache.hadoop.hbase.client.backoff
-
Default backoff policy that doesn't create any backoff for the client, regardless of load
- ClientBackoffPolicyFactory.NoBackoffPolicy(Configuration) - Constructor for class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
-
- clientPort - Variable in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKClusterKey
-
- ClientProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.Action - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Action
- ClientProtos.Action.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Action
- ClientProtos.ActionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.Authorizations - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Authorizations
- ClientProtos.Authorizations.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Authorizations
- ClientProtos.AuthorizationsOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.BulkLoadHFileRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BulkLoadHFileRequest
- ClientProtos.BulkLoadHFileRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BulkLoadHFileRequest
- ClientProtos.BulkLoadHFileRequest.FamilyPath - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BulkLoadHFileRequest.FamilyPath
- ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BulkLoadHFileRequest.FamilyPath
- ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.BulkLoadHFileRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.BulkLoadHFileResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BulkLoadHFileResponse
- ClientProtos.BulkLoadHFileResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BulkLoadHFileResponse
- ClientProtos.BulkLoadHFileResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.CellVisibility - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CellVisibility
- ClientProtos.CellVisibility.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CellVisibility
- ClientProtos.CellVisibilityOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.ClientService - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf service ClientService
- ClientProtos.ClientService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
-
- ClientProtos.ClientService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.ClientService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.ClientService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.Column - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Column
- ClientProtos.Column.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Column
- ClientProtos.ColumnOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.Condition - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Condition
- ClientProtos.Condition.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Condition
- ClientProtos.ConditionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.Consistency - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum Consistency
- ClientProtos.CoprocessorServiceCall - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CoprocessorServiceCall
- ClientProtos.CoprocessorServiceCall.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CoprocessorServiceCall
- ClientProtos.CoprocessorServiceCallOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.CoprocessorServiceRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CoprocessorServiceRequest
- ClientProtos.CoprocessorServiceRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CoprocessorServiceRequest
- ClientProtos.CoprocessorServiceRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.CoprocessorServiceResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CoprocessorServiceResponse
- ClientProtos.CoprocessorServiceResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CoprocessorServiceResponse
- ClientProtos.CoprocessorServiceResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.CoprocessorServiceResult - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CoprocessorServiceResult
- ClientProtos.CoprocessorServiceResult.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CoprocessorServiceResult
- ClientProtos.CoprocessorServiceResultOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.Get - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Get
- ClientProtos.Get.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Get
- ClientProtos.GetOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.GetRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetRequest
- ClientProtos.GetRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetRequest
- ClientProtos.GetRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.GetResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetResponse
- ClientProtos.GetResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetResponse
- ClientProtos.GetResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.MultiRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MultiRequest
- ClientProtos.MultiRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MultiRequest
- ClientProtos.MultiRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.MultiResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MultiResponse
- ClientProtos.MultiResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MultiResponse
- ClientProtos.MultiResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.MutateRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MutateRequest
- ClientProtos.MutateRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MutateRequest
- ClientProtos.MutateRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.MutateResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MutateResponse
- ClientProtos.MutateResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MutateResponse
- ClientProtos.MutateResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.MutationProto - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MutationProto
- ClientProtos.MutationProto.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MutationProto
- ClientProtos.MutationProto.ColumnValue - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MutationProto.ColumnValue
- ClientProtos.MutationProto.ColumnValue.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MutationProto.ColumnValue
- ClientProtos.MutationProto.ColumnValue.QualifierValue - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MutationProto.ColumnValue.QualifierValue
- ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MutationProto.ColumnValue.QualifierValue
- ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.MutationProto.ColumnValueOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.MutationProto.DeleteType - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum MutationProto.DeleteType
- ClientProtos.MutationProto.Durability - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum MutationProto.Durability
- ClientProtos.MutationProto.MutationType - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum MutationProto.MutationType
- ClientProtos.MutationProtoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.RegionAction - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionAction
- ClientProtos.RegionAction.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionAction
- ClientProtos.RegionActionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.RegionActionResult - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionActionResult
- ClientProtos.RegionActionResult.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionActionResult
- ClientProtos.RegionActionResultOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.RegionLoadStats - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionLoadStats
- ClientProtos.RegionLoadStats.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionLoadStats
- ClientProtos.RegionLoadStatsOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.Result - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Result
- ClientProtos.Result.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Result
- ClientProtos.ResultOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.ResultOrException - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ResultOrException
- ClientProtos.ResultOrException.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ResultOrException
- ClientProtos.ResultOrExceptionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.Scan - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Scan
- ClientProtos.Scan.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Scan
- ClientProtos.ScanOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.ScanRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ScanRequest
- ClientProtos.ScanRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ScanRequest
- ClientProtos.ScanRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientProtos.ScanResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ScanResponse
- ClientProtos.ScanResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ScanResponse
- ClientProtos.ScanResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClientScanner - Class in org.apache.hadoop.hbase.client
-
Implements the scanner interface for the HBase client.
- ClientScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.client.ClientScanner
-
Create a new ClientScanner for the specified table Note that the passed
Scan
's start
row maybe changed changed.
- ClientSideRegionScanner - Class in org.apache.hadoop.hbase.client
-
A client scanner for a region opened for read-only on the client side.
- ClientSideRegionScanner(Configuration, FileSystem, Path, HTableDescriptor, HRegionInfo, Scan, ScanMetrics) - Constructor for class org.apache.hadoop.hbase.client.ClientSideRegionScanner
-
- ClientSmallReversedScanner - Class in org.apache.hadoop.hbase.client
-
Client scanner for small reversed scan.
- ClientSmallReversedScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
-
Create a new ReversibleClientScanner for the specified table.
- ClientSmallScanner - Class in org.apache.hadoop.hbase.client
-
Client scanner for small scan.
- ClientSmallScanner(Configuration, Scan, TableName, ClusterConnection, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService, int) - Constructor for class org.apache.hadoop.hbase.client.ClientSmallScanner
-
Create a new ShortClientScanner for the specified table.
- ClientSmallScanner.SmallScannerCallableFactory - Class in org.apache.hadoop.hbase.client
-
- ClientSmallScanner.SmallScannerCallableFactory() - Constructor for class org.apache.hadoop.hbase.client.ClientSmallScanner.SmallScannerCallableFactory
-
- ClientSnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
-
Class to help with dealing with a snapshot description on the client side.
- ClientSnapshotDescriptionUtils() - Constructor for class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
-
- ClockOutOfSyncException - Exception in org.apache.hadoop.hbase
-
This exception is thrown by the master when a region server clock skew is
too high.
- ClockOutOfSyncException(String) - Constructor for exception org.apache.hadoop.hbase.ClockOutOfSyncException
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- clone() - Method in class org.apache.hadoop.hbase.KeyValue
-
Clones a KeyValue.
- clone() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- clone() - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
- clone() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
- clone() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
Public exposure of Object.clone() in order to allow clients to easily
capture current state.
- clone() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- cloneAndAddTags(Cell, List<Tag>) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Create a new KeyValue by copying existing cell and adding new tags
- cloneFamily(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneQualifier(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- cloneRegionInfo(HRegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Create a new
HRegionInfo
from the snapshot region info.
- cloneRow(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
get individual arrays for tests
- cloneSnapshot(byte[], TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new table by cloning the snapshot content.
- cloneSnapshot(String, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new table by cloning the snapshot content.
- CloneSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
-
Handler to Clone a snapshot.
- CloneSnapshotHandler(MasterServices, HBaseProtos.SnapshotDescription, HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- cloneTableSchema(HTableDescriptor, TableName) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Create a new table descriptor cloning the snapshot table schema.
- cloneValue(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- close() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- close() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
- close() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- close() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.ClientSideRegionScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
-
- close() - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner
-
- close() - Method in interface org.apache.hadoop.hbase.client.Connection
-
- close() - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
- close() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- close() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
- close() - Method in class org.apache.hadoop.hbase.client.HTable
-
- close() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- close() - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Closes all the HTable instances , belonging to all tables in the table
pool.
- close() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- close() - Method in class org.apache.hadoop.hbase.client.MetaScanner.MetaScannerVisitorBase
-
- close() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- close() - Method in interface org.apache.hadoop.hbase.client.ResultScanner
-
Closes the scanner and releases any resources it has allocated
- close() - Method in interface org.apache.hadoop.hbase.client.Table
-
Releases any resources held or pending changes in internal buffers.
- close() - Method in class org.apache.hadoop.hbase.client.TableSnapshotScanner
-
- close() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Close this filesystem object
- close() - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- close() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- close() - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec.ReusableGzipOutputStream
-
- close() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
Releases the compressor this writer uses to compress blocks into the
compressor pool.
- close() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Releases the resources used.
- close() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Close stream(s) if necessary.
- close() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
- close(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Close method with optional evictOnClose
- close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- close(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- close() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- close(Throwable) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
-
Close connection
- close() - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
-
Close netty
- close() - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
-
Stop all threads related to this client.
- close() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl
-
Stop all threads related to this client.
- close() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
-
Close the connection.
- close() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- close(Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat.TableRecordWriter
-
- close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- close() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueDeserializer
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
-
- close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat.MultiTableRecordWriter
-
- close(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat.TableRecordWriter
-
Closes the writer, in this case flush table commits.
- close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Closes the split.
- close() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Closes the split.
- close() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- close() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
-
- close() - Method in interface org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
-
- close() - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Shutdown the thread pools and release rpc resources
- close() - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Best effort attempt to close the threadpool via Thread.interrupt.
- close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
- close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- close() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- close() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
- close() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- close() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Cleanup method on operation completion
- close() - Method in class org.apache.hadoop.hbase.quotas.QuotaRetriever
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
-
Close this instance since it won't be used any more, try to put the chunks
back to pool
- close() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Close down this HRegion.
- close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Close down this HRegion.
- CLOSE - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.InternalScanner
-
Closes the scanner and releases any resources it has allocated
- close() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Close the KeyValue scanner.
- close() - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Shut down this Leases instance.
- close() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Close instance since it won't be used any more, try to put the chunks back to pool
- close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
Close the region's metrics as this region is closing.
- close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- close() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Close all the readers We don't need to worry about subsequent requests because the Region
holds a write lock that will prevent any more reads or writes.
- close(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- close() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- close() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
- close() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- close() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- close() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- close() - Method in class org.apache.hadoop.hbase.rest.ResultGenerator
-
- close() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
-
- close() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- close() - Method in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- close() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
-
Flushes and closes (I think, in the superclass) the stream.
- close() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- close() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- close() - Method in class org.apache.hadoop.hbase.util.MultiHConnection
-
Close the open connections and shutdown the batchpool
- close() - Method in class org.apache.hadoop.hbase.wal.BoundedRegionGroupingProvider
-
- close() - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- close() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Caller no longer needs any edits from this WAL.
- close() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Shutdown all WALs and clean up any underlying storage.
- close() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
shutdown utstanding WALs and clean up any persisted state.
- close() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- close() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Close the connection to ZooKeeper.
- CLOSE_PARAN_NODE - Static variable in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- CLOSE_SCANNER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- closeAfterLeasesExpire() - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Shuts down this lease instance when all outstanding leases expire.
- closeAllRegions(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Closes all regions.
- closeAndCleanCompleted - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- closeConnection() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
-
- closeConnection(RpcServer.Connection) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- closed - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- closed - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- CLOSED_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
- CLOSED_PARAN - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
- CLOSED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
-
CLOSED = 6;
- CLOSED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode
-
CLOSED = 2;
- ClosedRegionHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handles CLOSED region event on Master.
- ClosedRegionHandler(Server, AssignmentManager, HRegionInfo) - Constructor for class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
-
- closeHRegion(HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- CloseMetaHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handles closing of the root region on a region server.
- CloseMetaHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseMetaHandler
-
- closeOutputStream - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
True if we opened the outputStream
(and so will close it).
- closeReader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- closeReader() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationWALReaderManager
-
Close the current reader
- closeReceivers() - Method in class org.apache.hadoop.hbase.trace.SpanReceiverHost
-
Calls close() on all SpanReceivers created by this SpanReceiverHost.
- closeRecoveredQueue(ReplicationSourceInterface) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Clear the references to the specified old source
- closeRegion(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Close a region.
- closeRegion(byte[], String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Close a region.
- closeRegion(ServerName, HRegionInfo) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Close a region.
- closeRegion(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Close a region.
- closeRegion(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Close a region.
- closeRegion(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Close a region.
- closeRegion(RpcController, AdminProtos.CloseRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
-
- closeRegion(RpcController, AdminProtos.CloseRegionRequest, RpcCallback<AdminProtos.CloseRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
rpc CloseRegion(.CloseRegionRequest) returns (.CloseRegionResponse);
- closeRegion(RpcController, AdminProtos.CloseRegionRequest, RpcCallback<AdminProtos.CloseRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
-
rpc CloseRegion(.CloseRegionRequest) returns (.CloseRegionResponse);
- closeRegion(RpcController, AdminProtos.CloseRegionRequest, RpcCallback<AdminProtos.CloseRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
-
- closeRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, byte[], boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to close a region given a region name
using admin protocol.
- closeRegion(RpcController, AdminProtos.AdminService.BlockingInterface, ServerName, byte[], int, ServerName, boolean) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to close a region given a region name
using admin protocol.
- closeRegion(String, boolean, CloseRegionCoordination.CloseRegionDetails, ServerName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Close asynchronously a region, can be called from the master or internally by the regionserver
when stopping.
- closeRegion(RpcController, AdminProtos.CloseRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Close a region on the region server.
- CloseRegionCoordination - Interface in org.apache.hadoop.hbase.coordination
-
Coordinated operations for close region handlers.
- closeRegionCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- CloseRegionCoordination.CloseRegionDetails - Interface in org.apache.hadoop.hbase.coordination
-
Marker interface for region closing tasks.
- CloseRegionHandler - Class in org.apache.hadoop.hbase.regionserver.handler
-
Handles closing of a region on a region server.
- CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
This method used internally by the RegionServer to close out regions.
- CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails, ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails, EventType) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- CloseRegionHandler(Server, RegionServerServices, HRegionInfo, boolean, CloseRegionCoordination, CloseRegionCoordination.CloseRegionDetails, EventType, ServerName) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- closeRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- closeRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Closes the lock.
- closeRegionOperation() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Closes the region operation lock.
- closeRegionSilentlyAndWait(ClusterConnection, ServerName, HRegionInfo, long) - Static method in class org.apache.hadoop.hbase.master.ServerManager
-
Contacts a region server and waits up to timeout ms
to close the region.
- closeRegionSilentlyAndWait(HConnection, ServerName, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Contacts a region server and waits up to hbase.hbck.close.timeout ms
(default 120s) to close the region.
- closeRegionWithEncodedRegionName(String, String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
For expert-admins.
- closeRegionWithEncodedRegionName(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
For expert-admins.
- closeScanner(int, AsyncMethodCallback<THBaseService.AsyncClient.closeScanner_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- closeScanner(int, AsyncMethodCallback<THBaseService.AsyncClient.closeScanner_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- closeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- closeScanner(int) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Closes the scanner.
- closeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- CLOSEST_ROW_BEFORE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- closeStreams() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
Closes the backing streams
- closeTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- closeTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- closeTablePool(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Closes all the HTable instances , belonging to the given table, in the
table pool.
- closeTablePool(byte[]) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
- closing - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- CLOSING_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
-
CLOSING = 5;
- Cluster - Class in org.apache.hadoop.hbase.rest.client
-
A list of 'host:port' addresses of HTTP servers operating as a single
entity, for example multiple redundant web service gateways.
- Cluster() - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
-
Constructor
- Cluster(List<String>) - Constructor for class org.apache.hadoop.hbase.rest.client.Cluster
-
Constructor
- CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Cluster is in distributed mode or not
- CLUSTER_ID_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for cluster ID
- CLUSTER_ID_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- CLUSTER_ID_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CLUSTER_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
- CLUSTER_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- CLUSTER_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- CLUSTER_ID_FILE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
name of the file for unique cluster ID
- CLUSTER_ID_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- CLUSTER_ID_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- CLUSTER_IDS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- CLUSTER_IS_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Cluster is fully-distributed
- CLUSTER_IS_LOCAL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Cluster is standalone or pseudo-distributed
- CLUSTER_REQUESTS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- CLUSTER_STATUS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
- CLUSTER_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaScope
-
CLUSTER = 1;
- ClusterConnection - Interface in org.apache.hadoop.hbase.client
-
Internal methods on Connection that should not be used by user code.
- clusterConnection - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Cluster connection to be shared by services.
- ClusterId - Class in org.apache.hadoop.hbase
-
The identifier for this cluster.
- ClusterId() - Constructor for class org.apache.hadoop.hbase.ClusterId
-
New ClusterID.
- ClusterId(String) - Constructor for class org.apache.hadoop.hbase.ClusterId
-
- clusterId - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- ClusterIdProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- ClusterIdProtos.ClusterId - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ClusterId
- ClusterIdProtos.ClusterId.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ClusterId
- ClusterIdProtos.ClusterIdOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- clusterIds - Variable in class org.apache.hadoop.hbase.wal.WALKey
-
- clusterIdZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- CLUSTERKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- ClusterLoadState - Class in org.apache.hadoop.hbase.master.balancer
-
Class used to hold the current state of the cluster and how balanced it is.
- ClusterLoadState(Map<ServerName, List<HRegionInfo>>) - Constructor for class org.apache.hadoop.hbase.master.balancer.ClusterLoadState
-
- clusterStateZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- ClusterStatus - Class in org.apache.hadoop.hbase
-
Status information on the HBase cluster.
- ClusterStatus() - Constructor for class org.apache.hadoop.hbase.ClusterStatus
-
Deprecated.
As of release 0.96
(HBASE-6038).
This will be removed in HBase 2.0.0.
Used by Writables and Writables are going away.
- ClusterStatus(String, String, Map<ServerName, ServerLoad>, Collection<ServerName>, ServerName, Collection<ServerName>, Map<String, RegionState>, String[], Boolean) - Constructor for class org.apache.hadoop.hbase.ClusterStatus
-
- clusterStatus - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- ClusterStatusChore - Class in org.apache.hadoop.hbase.master.balancer
-
Chore that will feed the balancer the cluster status.
- ClusterStatusChore(HMaster, LoadBalancer) - Constructor for class org.apache.hadoop.hbase.master.balancer.ClusterStatusChore
-
- ClusterStatusProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- ClusterStatusProtos.ClusterStatus - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ClusterStatus
- ClusterStatusProtos.ClusterStatus.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ClusterStatus
- ClusterStatusProtos.ClusterStatusOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClusterStatusProtos.LiveServerInfo - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type LiveServerInfo
- ClusterStatusProtos.LiveServerInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type LiveServerInfo
- ClusterStatusProtos.LiveServerInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClusterStatusProtos.RegionInTransition - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionInTransition
- ClusterStatusProtos.RegionInTransition.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionInTransition
- ClusterStatusProtos.RegionInTransitionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClusterStatusProtos.RegionLoad - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionLoad
- ClusterStatusProtos.RegionLoad.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionLoad
- ClusterStatusProtos.RegionLoadOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClusterStatusProtos.RegionState - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionState
- ClusterStatusProtos.RegionState.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionState
- ClusterStatusProtos.RegionState.State - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum RegionState.State
- ClusterStatusProtos.RegionStateOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClusterStatusProtos.RegionStoreSequenceIds - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionStoreSequenceIds
- ClusterStatusProtos.RegionStoreSequenceIds.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionStoreSequenceIds
- ClusterStatusProtos.RegionStoreSequenceIdsOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClusterStatusProtos.ReplicationLoadSink - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ReplicationLoadSink
- ClusterStatusProtos.ReplicationLoadSink.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ReplicationLoadSink
- ClusterStatusProtos.ReplicationLoadSinkOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClusterStatusProtos.ReplicationLoadSource - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ReplicationLoadSource
- ClusterStatusProtos.ReplicationLoadSource.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ReplicationLoadSource
- ClusterStatusProtos.ReplicationLoadSourceOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClusterStatusProtos.ServerLoad - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ServerLoad
- ClusterStatusProtos.ServerLoad.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ServerLoad
- ClusterStatusProtos.ServerLoadOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClusterStatusProtos.StoreSequenceId - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type StoreSequenceId
- ClusterStatusProtos.StoreSequenceId.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type StoreSequenceId
- ClusterStatusProtos.StoreSequenceIdOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ClusterStatusPublisher - Class in org.apache.hadoop.hbase.master
-
Class to publish the cluster status to the client.
- ClusterStatusPublisher(HMaster, Configuration, Class<? extends ClusterStatusPublisher.Publisher>) - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- ClusterStatusPublisher() - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- ClusterStatusPublisher.MulticastPublisher - Class in org.apache.hadoop.hbase.master
-
- ClusterStatusPublisher.MulticastPublisher() - Constructor for class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
-
- ClusterStatusPublisher.Publisher - Interface in org.apache.hadoop.hbase.master
-
- clusterStatusTracker - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ClusterStatusTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracker on cluster settings up in zookeeper.
- ClusterStatusTracker(ZooKeeperWatcher, Abortable) - Constructor for class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Creates a cluster status tracker.
- cmdLineArgs - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- cmp(int) - Method in enum org.apache.hadoop.hbase.util.Order
-
Returns the adjusted trichotomous value according to the ordering imposed by this
Order
.
- code() - Method in enum org.apache.hadoop.hbase.security.access.Permission.Action
-
- code - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
-
The code for this method.
- code - Variable in enum org.apache.hadoop.hbase.wal.WALKey.Version
-
- Codec - Interface in org.apache.hadoop.hbase.codec
-
Encoder/Decoder for Cell.
- codec - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- Codec.Decoder - Interface in org.apache.hadoop.hbase.codec
-
Implementations should implicitly clean up any resources allocated when the
Decoder/CellScanner runs off the end of the cell block.
- Codec.Encoder - Interface in org.apache.hadoop.hbase.codec
-
Call flush when done.
- CodecException - Exception in org.apache.hadoop.hbase.codec
-
Thrown when problems in the codec whether setup or context.
- CodecException() - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
-
- CodecException(String) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
-
- CodecException(Throwable) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
-
- CodecException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.codec.CodecException
-
- codeToType(byte) - Static method in enum org.apache.hadoop.hbase.KeyValue.Type
-
Cannot rely on enum ordinals .
- codeToType(byte) - Static method in enum org.apache.hadoop.hbase.util.ChecksumType
-
Cannot rely on enum ordinals .
- colDescFromHbase(HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a new Thrift ColumnDescriptor "struct" based on
an Hbase HColumnDescriptor object.
- colDescFromThrift(ColumnDescriptor) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
This utility method creates a new Hbase HColumnDescriptor object based on a
Thrift ColumnDescriptor "struct".
- CollectionBackedScanner - Class in org.apache.hadoop.hbase.util
-
Utility scanner that wraps a sortable collection and serves
as a KeyValueScanner.
- CollectionBackedScanner(SortedSet<Cell>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(SortedSet<Cell>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(List<Cell>) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(List<Cell>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionBackedScanner(KeyValue.KVComparator, Cell...) - Constructor for class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- CollectionUtils - Class in org.apache.hadoop.hbase.util
-
Utility methods for dealing with Collections, including treating null collections as empty.
- CollectionUtils() - Constructor for class org.apache.hadoop.hbase.util.CollectionUtils
-
- COLON - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for colon (:)
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
name of column
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
column name
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
name of column whose value is to be deleted
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
name of column whose value is to be deleted
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
column name
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
column name
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
column name
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- column - Variable in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- COLUMN_FAMILIES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- COLUMN_FAMILIES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
- COLUMN_FAMILIES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
- COLUMN_FAMILY_DELIM_ARRAY - Static variable in class org.apache.hadoop.hbase.KeyValue
-
- COLUMN_FAMILY_DELIMITER - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Colon character in UTF-8
- COLUMN_FAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- COLUMN_FAMILY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- COLUMN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- COLUMN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- COLUMN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- COLUMN_LIST - Static variable in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
space delimited list of columns
- COLUMN_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
- COLUMN_OFFSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
- COLUMN_QUALIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- COLUMN_QUALIFIER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- COLUMN_VALUE - Static variable in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
-
COLUMN = 2;
- COLUMN_VALUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- columnBuffer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
-
- columnBuffer - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
-
- ColumnCount - Class in org.apache.hadoop.hbase.regionserver
-
Simple wrapper for a byte buffer and a counter.
- ColumnCount(byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Constructor
- ColumnCount(byte[], int) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Constructor
- ColumnCount(byte[], int, int, int) - Constructor for class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Constuctor
- ColumnCountGetFilter - Class in org.apache.hadoop.hbase.filter
-
Simple filter that returns first N columns on row only.
- ColumnCountGetFilter(int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- ColumnDescriptor - Class in org.apache.hadoop.hbase.thrift.generated
-
An HColumnDescriptor contains information about a column family
such as the number of versions, compression settings, etc.
- ColumnDescriptor() - Constructor for class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- ColumnDescriptor(ByteBuffer, int, String, boolean, String, int, int, boolean, int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- ColumnDescriptor(ColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
Performs a deep copy on other.
- ColumnDescriptor._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- columnFamilies - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
list of column family descriptors
- columnFamily - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- columnFamily - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- COLUMNFAMILY_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
- COLUMNFAMILY_SCHEMA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
- COLUMNFAMILY_SCHEMA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
- ColumnInterpreter<T,S,P extends com.google.protobuf.Message,Q extends com.google.protobuf.Message,R extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.coprocessor
-
Defines how value for specific column is interpreted and provides utility
methods like compare, add, multiply etc for them.
- ColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- columnLength - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
-
- columnName - Variable in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- ColumnNodeReader - Class in org.apache.hadoop.hbase.codec.prefixtree.decode.column
-
- ColumnNodeReader(byte[], ColumnNodeType) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
-
construct
- columnNodeReader - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
-
- ColumnNodeType - Enum in org.apache.hadoop.hbase.codec.prefixtree.encode.other
-
Specifies the type of columnnode writer.
- ColumnNodeWriter - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.column
-
Column nodes can be either family nodes or qualifier nodes, as both sections encode similarly.
- ColumnNodeWriter(PrefixTreeBlockMeta, TokenizerNode, ColumnNodeType) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
-
construct
- columnOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
-
- ColumnPaginationFilter - Class in org.apache.hadoop.hbase.filter
-
A filter, based on the ColumnCountGetFilter, takes two arguments: limit and offset.
- ColumnPaginationFilter(int, int) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
Initializes filter with an integer offset and limit.
- ColumnPaginationFilter(int, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
Initializes filter with a string/bookmark based offset and limit.
- ColumnPrefixFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used for selecting only those keys with columns that matches
a particular prefix.
- ColumnPrefixFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- columnQualifier - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- columnQualifier - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- ColumnRangeFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used for selecting only those keys with columns that are
between minColumn to maxColumn.
- ColumnRangeFilter(byte[], boolean, byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
Create a filter to select those keys with columns that are between minColumn
and maxColumn.
- ColumnReader - Class in org.apache.hadoop.hbase.codec.prefixtree.decode.column
-
Position one of these appropriately in the data block and you can call its methods to retrieve
the family or qualifier at the current position.
- ColumnReader(byte[], ColumnNodeType) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
-
construct
- columns - Variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
- columns - Variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
The grouping columns.
- columns - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
List of columns to return, null for all columns
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
List of columns to return, null for all columns
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
List of columns to return, null for all columns
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
List of columns to return, null for all columns
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
columns to scan.
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
columns to scan.
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
the columns you want returned
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
columns to scan.
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
columns to scan.
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- columns - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- columns - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- COLUMNS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- COLUMNS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- COLUMNS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- ColumnSchemaMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ColumnSchemaMessage.ColumnSchema - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema
- ColumnSchemaMessage.ColumnSchema.Attribute - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute
- ColumnSchemaMessage.ColumnSchema.Attribute.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute
- ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ColumnSchemaMessage.ColumnSchema.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema
- ColumnSchemaMessage.ColumnSchemaOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ColumnSchemaModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of a column family schema.
- ColumnSchemaModel() - Constructor for class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
Default constructor
- ColumnSectionWriter - Class in org.apache.hadoop.hbase.codec.prefixtree.encode.column
-
Takes the tokenized family or qualifier data and flattens it into a stream of bytes.
- ColumnSectionWriter() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
-
construct
- ColumnSectionWriter(PrefixTreeBlockMeta, Tokenizer, ColumnNodeType) - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
-
- ColumnTracker - Interface in org.apache.hadoop.hbase.regionserver
-
Implementing classes of this interface will be used for the tracking
and enforcement of columns and numbers of versions and timeToLive during
the course of a Get or Scan operation.
- columnValues - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- columnValues - Variable in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- com.google.protobuf - package com.google.protobuf
-
- CombinedBlockCache - Class in org.apache.hadoop.hbase.io.hfile
-
- CombinedBlockCache(LruBlockCache, BlockCache) - Constructor for class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- CombinedBlockCache.CombinedCacheStats - Class in org.apache.hadoop.hbase.io.hfile
-
- combinedCacheStats - Variable in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- combineWith(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Combines the request with other request.
- comConf - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- COMMA - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for a comma
- COMMIT_FLUSH_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.FlushAction
-
COMMIT_FLUSH = 1;
- commitOpenOnMasterSide(AssignmentManager, HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
-
Commits opening operation on HM side (steps required for "commit"
are determined by coordination implementation).
- commitOpenOnMasterSide(AssignmentManager, HRegionInfo, OpenRegionCoordination.OpenRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
-
- commitStoreFile(String, Path) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Move the file from a build/temp location to the main family store directory.
- commitTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- commitWriters(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- commitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- commitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Subclasses override this method to be called at the end of a successful sequence of
append; all appends are processed before this method is called.
- commitWritersInternal() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- compact(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a table.
- compact(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a column family within a table.
- compact(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a table.
- compact(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- compact(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- compact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a column family within a table.
- compact(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- compact(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- compact(CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
Runs the compaction based on current selection.
- compact(CompactionThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- compact(CompactionRequest, CompactionThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
-
Do a minor/major compaction on an explicit set of storefiles from a Store.
- compact(CompactionRequest, List<byte[]>, byte[], byte[], CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- compact(CompactionRequest, List<byte[]>, byte[], byte[], CompactionThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- compact(CompactionRequest, int, long, byte[], byte[], byte[], byte[], CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- compact(CompactionRequest, int, long, byte[], byte[], byte[], byte[], CompactionThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- compact(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- compact(CompactionContext, Store, CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- compact(CompactionContext, Store, CompactionThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- compact(CompactionContext, CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Compact the StoreFiles.
- compact(CompactionContext, CompactionThroughputController, User) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- compact(boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Synchronously compact all stores in the region.
- compact(CompactionContext, CompactionThroughputController) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Deprecated.
see compact(CompactionContext, CompactionThroughputController, User)
- compact(CompactionContext, CompactionThroughputController, User) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- compact(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.compact_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- compact(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.compact_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- compact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- compact(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
- compact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- COMPACT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type
-
COMPACT = 6;
- compactBloom() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Compact the Bloom filter before writing metadata & data to disk.
- compactBloom() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- compactBloom() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- COMPACTCHECKER_INTERVAL_MULTIPLIER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- COMPACTED_CELLS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTED_CELLS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTED_CELLS_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTED_CELLS_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- compactForTesting(Collection<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
-
Compact a list of files for testing.
- COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used by HBase Shell interface to access this metadata
attribute which denotes if the table is compaction enabled
- COMPACTION_INPUT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- COMPACTION_KV_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for the maximum batch of KVs to be used in flushes and compactions
- COMPACTION_KV_MAX_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- COMPACTION_OUTPUT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- COMPACTION_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- COMPACTION_STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
- COMPACTION_STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- COMPACTION_TIMESTAMP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
- compactionCompression - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- CompactionConfiguration - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Compaction configuration for a particular instance of HStore.
- CompactionContext - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This class holds all "physical" details necessary to run a compaction,
and abstracts away the details specific to a particular compaction.
- CompactionContext() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- CompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
-
A compaction policy determines how to select files for compaction,
how to compact them, and how to generate the compacted files.
- CompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- compactionPolicy - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- CompactionProgress - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This class holds information relevant for tracking the progress of a
compaction.
- CompactionProgress(long) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Constructor
- CompactionRequest - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This class holds all logical details necessary to run a compaction.
- CompactionRequest() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
This ctor should be used by coprocessors that want to subclass CompactionRequest.
- CompactionRequest(Collection<StoreFile>) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- CompactionRequestor - Interface in org.apache.hadoop.hbase.regionserver
-
- COMPACTIONS_COMPLETED_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- COMPACTIONS_COMPLETED_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- CompactionThroughputController - Interface in org.apache.hadoop.hbase.regionserver.compactions
-
A utility that constrains the total throughput of one or more simultaneous flows (compactions) by
sleeping when necessary.
- CompactionThroughputControllerFactory - Class in org.apache.hadoop.hbase.regionserver.compactions
-
- CompactionThroughputControllerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputControllerFactory
-
- CompactionTool - Class in org.apache.hadoop.hbase.regionserver
-
- CompactionTool() - Constructor for class org.apache.hadoop.hbase.regionserver.CompactionTool
-
- Compactor - Class in org.apache.hadoop.hbase.regionserver.compactions
-
A compactor is a compaction algorithm associated a given policy.
- compactor - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- Compactor.CellSink - Interface in org.apache.hadoop.hbase.regionserver.compactions
-
- Compactor.FileDetails - Class in org.apache.hadoop.hbase.regionserver.compactions
-
The sole reason this class exists is that java has no ref/out/pointer parameters.
- Compactor.FileDetails() - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.Compactor.FileDetails
-
- compactRecentForTestingAssumingDefaultPolicy(int) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
This method tries to compact N recent files for testing.
- compactRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact an individual region.
- compactRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact a column family within a region.
- compactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact an individual region.
- compactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact a column family within a region.
- compactRegion(RpcController, AdminProtos.CompactRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
-
- compactRegion(RpcController, AdminProtos.CompactRegionRequest, RpcCallback<AdminProtos.CompactRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
rpc CompactRegion(.CompactRegionRequest) returns (.CompactRegionResponse);
- compactRegion(RpcController, AdminProtos.CompactRegionRequest, RpcCallback<AdminProtos.CompactRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
-
rpc CompactRegion(.CompactRegionRequest) returns (.CompactRegionResponse);
- compactRegion(RpcController, AdminProtos.CompactRegionRequest, RpcCallback<AdminProtos.CompactRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
-
- compactRegion(RpcController, AdminProtos.CompactRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Compact a region on the region server.
- compactRegionServer(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Compact all regions on the region server
- compactRegionServer(ServerName, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Compact all regions on the region server
- CompactSplitThread - Class in org.apache.hadoop.hbase.regionserver
-
Compact region on request and then run split if appropriate
- compactSplitThread - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- compactStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function that compact all the stores synchronously
It is used by utilities and testing
- COMPARABLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
- COMPARABLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
- COMPARABLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
- COMPARABLE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
- comparator - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
-
- comparator - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- comparator - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Key comparator
- comparator - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Key comparator.
- comparator() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- comparator - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- COMPARATOR - Static variable in class org.apache.hadoop.hbase.KeyValue
-
Comparator for plain key/values; i.e.
- comparator() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- comparator - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- comparator() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- comparator - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
Comparator used to compare Bloom filter keys
- comparator() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- COMPARATOR - Static variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.ZNodeComparator
-
- COMPARATOR_CLASS_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- COMPARATOR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- COMPARATOR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- COMPARATOR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- ComparatorProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- ComparatorProtos.BinaryComparator - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BinaryComparator
- ComparatorProtos.BinaryComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BinaryComparator
- ComparatorProtos.BinaryComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ComparatorProtos.BinaryPrefixComparator - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BinaryPrefixComparator
- ComparatorProtos.BinaryPrefixComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BinaryPrefixComparator
- ComparatorProtos.BinaryPrefixComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ComparatorProtos.BitComparator - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BitComparator
- ComparatorProtos.BitComparator.BitwiseOp - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum BitComparator.BitwiseOp
- ComparatorProtos.BitComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BitComparator
- ComparatorProtos.BitComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ComparatorProtos.ByteArrayComparable - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ByteArrayComparable
- ComparatorProtos.ByteArrayComparable.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ByteArrayComparable
- ComparatorProtos.ByteArrayComparableOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ComparatorProtos.Comparator - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Comparator
- ComparatorProtos.Comparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Comparator
- ComparatorProtos.ComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ComparatorProtos.LongComparator - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type LongComparator
- ComparatorProtos.LongComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type LongComparator
- ComparatorProtos.LongComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ComparatorProtos.NullComparator - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type NullComparator
- ComparatorProtos.NullComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type NullComparator
- ComparatorProtos.NullComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ComparatorProtos.RegexStringComparator - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegexStringComparator
- ComparatorProtos.RegexStringComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegexStringComparator
- ComparatorProtos.RegexStringComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ComparatorProtos.SubstringComparator - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SubstringComparator
- ComparatorProtos.SubstringComparator.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SubstringComparator
- ComparatorProtos.SubstringComparatorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparator
-
- compare(Cell, Cell, boolean) - Static method in class org.apache.hadoop.hbase.CellComparator
-
Compare cells.
- compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparator.RowComparator
-
- compare(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- compare(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- compare(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- compare(TokenizerNode, TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenDepthComparator
-
- compare(T, T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This takes care if either of arguments are null.
- compare(HDFSBlocksDistribution.HostAndWeight, HDFSBlocksDistribution.HostAndWeight) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
-
- compare(long) - Method in class org.apache.hadoop.hbase.io.TimeRange
-
Compare the timestamp to timerange
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Compares the Key of a cell -- with fields being more significant in this order:
rowkey, colfam/qual, timestamp, type, mvcc
- compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
Compare key portion of a
KeyValue
for keys in
hbase:meta
table.
- compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.RawBytesComparator
-
- compare(KeyValue, KeyValue) - Method in class org.apache.hadoop.hbase.KeyValue.RowOnlyComparator
-
- compare(RegionPlan, RegionPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
-
- compare(KeyValueScanner, KeyValueScanner) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
-
- compare(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
-
Compares two KeyValue
- compare(Path, Path) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource.LogsComparator
-
- compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.ByteArrayComparator
-
- compare(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
-
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Bytes.RowEndKeyComparator
-
- compare(String, String) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.ZNodeComparator
-
- COMPARE_FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- COMPARE_FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
- COMPARE_FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
- COMPARE_FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
- COMPARE_FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
- COMPARE_OP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- COMPARE_OP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- COMPARE_TYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- compareColumns(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
-
- compareColumns(byte[], int, int, int, byte[], int, int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compareColumns(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compareCommonFamilyPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.CellComparator
-
- compareCommonQualifierPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.CellComparator
-
- compareCommonRowPrefix(Cell, Cell, int) - Static method in class org.apache.hadoop.hbase.CellComparator
-
- compareFamilies(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
-
- compareFamilies(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- CompareFilter - Class in org.apache.hadoop.hbase.filter
-
This is a generic filter to be used to filter by comparison.
- CompareFilter(CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.CompareFilter
-
Constructor.
- CompareFilter.CompareOp - Enum in org.apache.hadoop.hbase.filter
-
Comparison operators.
- compareFlatKey(Cell, Cell) - Method in class org.apache.hadoop.hbase.CellComparator
-
- compareFlatKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Compares left to right assuming that left,loffset,llength and right,roffset,rlength are
full KVs laid out in a flat byte[]s.
- compareFlatKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compareFlatKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.RawBytesComparator
-
Deprecated.
Since 0.99.2.
- compareIgnoringPrefix(int, byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Overridden
- compareIgnoringPrefix(int, byte[], int, int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.KeyValue.SamePrefixComparator
-
Compare two keys assuming that the first n bytes are the same.
- compareKey(KeyValue.KVComparator, byte[], int, int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
- compareKey(KeyValue.KVComparator, Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
- compareKey(KeyValue.KVComparator, byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Compare the given key against the current key
- compareKey(KeyValue.KVComparator, Cell) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
- compareKey(KeyValue.KVComparator, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
Compare the given key against the current key
- compareKey(KeyValue.KVComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- compareKey(KeyValue.KVComparator, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- compareKey(KeyValue.KVComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- compareKey(KeyValue.KVComparator, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- compareKey(KeyValue.KVComparator, Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- compareKey(Cell, byte[], int, int, byte[], int, int, byte[], int, int, long, byte) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compareKeyForNextColumn(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- compareKeyForNextRow(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- compareOnlyKeyPortion(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compareOnlyKeyPortion(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
- compareOnlyKeyPortion(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.RawBytesComparator
-
- compareOp - Variable in class org.apache.hadoop.hbase.filter.CompareFilter
-
- compareOp - Variable in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- compareQualifiers(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
-
- compareResults(Result, Result) - Static method in class org.apache.hadoop.hbase.client.Result
-
Does a deep comparison of two Results, down to the byte arrays.
- compareRowKey(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Compares the only the user specified portion of a Key.
- compareRowKey(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
Override the row key comparison to parse and compare the meta row key parts.
- compareRows(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
-
Do not use comparing rows from hbase:meta.
- compareRows(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellComparator
-
Do not use comparing rows from hbase:meta.
- compareRows(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
Get the b[],o,l for left and right rowkey portions and compare.
- compareRows(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
- compareTimestamps(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
-
- compareTimestamps(Cell, Cell) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- compareTo(Object) - Method in class org.apache.hadoop.hbase.client.Action
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Get
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Increment
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- compareTo(Row) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- compareTo(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- compareTo(Runnable) - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Default prioritized runnable comparator which implements a FIFO ordering.
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
Special compareTo method for subclasses, to avoid
copying byte[] unnecessarily.
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.LongComparator
-
- compareTo(MultiRowRangeFilter.RowRange) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
- compareTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- compareTo(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- compareTo(HRegionInfo) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- compareTo(HRegionLocation) - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- compareTo(HTableDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Compares the descriptor with another descriptor which is passed as a parameter.
- compareTo(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- compareTo(ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Define the sort order of the BytesWritable.
- compareTo(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Compares the bytes in this object to the specified byte array
- compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- compareTo(TableSplit) - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Compares this split against the given one.
- compareTo(RegionPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Compare the region info.
- compareTo(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- compareTo(ProcedureWALFile) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
- compareTo(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
This function will define where in the priority queue the request will
end up.
- compareTo(MetricsRegionSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- compareTo(ServerName) - Method in class org.apache.hadoop.hbase.ServerName
-
- compareTo(TableName) - Method in class org.apache.hadoop.hbase.TableName
-
For performance reasons, the ordering is not lexicographic.
- compareTo(AlreadyExists) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- compareTo(BatchMutation) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- compareTo(ColumnDescriptor) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- compareTo(Hbase.append_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
- compareTo(Hbase.append_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- compareTo(Hbase.atomicIncrement_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- compareTo(Hbase.atomicIncrement_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- compareTo(Hbase.checkAndPut_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- compareTo(Hbase.checkAndPut_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- compareTo(Hbase.compact_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- compareTo(Hbase.compact_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- compareTo(Hbase.createTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- compareTo(Hbase.createTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- compareTo(Hbase.deleteAll_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- compareTo(Hbase.deleteAll_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- compareTo(Hbase.deleteAllRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- compareTo(Hbase.deleteAllRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- compareTo(Hbase.deleteAllRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- compareTo(Hbase.deleteAllRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- compareTo(Hbase.deleteAllTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- compareTo(Hbase.deleteAllTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- compareTo(Hbase.deleteTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- compareTo(Hbase.deleteTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- compareTo(Hbase.disableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- compareTo(Hbase.disableTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- compareTo(Hbase.enableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- compareTo(Hbase.enableTable_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- compareTo(Hbase.get_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- compareTo(Hbase.get_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- compareTo(Hbase.getColumnDescriptors_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- compareTo(Hbase.getColumnDescriptors_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- compareTo(Hbase.getRegionInfo_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- compareTo(Hbase.getRegionInfo_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- compareTo(Hbase.getRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- compareTo(Hbase.getRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- compareTo(Hbase.getRowOrBefore_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- compareTo(Hbase.getRowOrBefore_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- compareTo(Hbase.getRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- compareTo(Hbase.getRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- compareTo(Hbase.getRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- compareTo(Hbase.getRowsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- compareTo(Hbase.getRowsWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- compareTo(Hbase.getRowsWithColumns_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- compareTo(Hbase.getRowsWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- compareTo(Hbase.getRowsWithColumnsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- compareTo(Hbase.getRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- compareTo(Hbase.getRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- compareTo(Hbase.getRowWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- compareTo(Hbase.getRowWithColumns_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- compareTo(Hbase.getRowWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- compareTo(Hbase.getRowWithColumnsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- compareTo(Hbase.getTableNames_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- compareTo(Hbase.getTableNames_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- compareTo(Hbase.getTableRegions_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- compareTo(Hbase.getTableRegions_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- compareTo(Hbase.getVer_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- compareTo(Hbase.getVer_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- compareTo(Hbase.getVerTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- compareTo(Hbase.getVerTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- compareTo(Hbase.increment_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- compareTo(Hbase.increment_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- compareTo(Hbase.incrementRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- compareTo(Hbase.incrementRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- compareTo(Hbase.isTableEnabled_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- compareTo(Hbase.isTableEnabled_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- compareTo(Hbase.majorCompact_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- compareTo(Hbase.majorCompact_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- compareTo(Hbase.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- compareTo(Hbase.mutateRow_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- compareTo(Hbase.mutateRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- compareTo(Hbase.mutateRows_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- compareTo(Hbase.mutateRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- compareTo(Hbase.mutateRowsTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- compareTo(Hbase.mutateRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- compareTo(Hbase.mutateRowTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- compareTo(Hbase.scannerClose_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- compareTo(Hbase.scannerClose_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- compareTo(Hbase.scannerGet_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- compareTo(Hbase.scannerGet_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- compareTo(Hbase.scannerGetList_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- compareTo(Hbase.scannerGetList_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- compareTo(Hbase.scannerOpen_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- compareTo(Hbase.scannerOpen_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- compareTo(Hbase.scannerOpenTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- compareTo(Hbase.scannerOpenTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- compareTo(Hbase.scannerOpenWithPrefix_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- compareTo(Hbase.scannerOpenWithPrefix_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- compareTo(Hbase.scannerOpenWithScan_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- compareTo(Hbase.scannerOpenWithScan_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- compareTo(Hbase.scannerOpenWithStop_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- compareTo(Hbase.scannerOpenWithStop_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- compareTo(Hbase.scannerOpenWithStopTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- compareTo(Hbase.scannerOpenWithStopTs_result) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- compareTo(IllegalArgument) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- compareTo(IOError) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- compareTo(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- compareTo(TAppend) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- compareTo(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- compareTo(TColumn) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- compareTo(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- compareTo(TRegionInfo) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- compareTo(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- compareTo(TScan) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- compareTo(TAppend) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- compareTo(TAuthorization) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- compareTo(TCellVisibility) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
-
- compareTo(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- compareTo(TColumnIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- compareTo(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- compareTo(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- compareTo(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- compareTo(THBaseService.append_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
- compareTo(THBaseService.append_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- compareTo(THBaseService.checkAndDelete_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- compareTo(THBaseService.checkAndDelete_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- compareTo(THBaseService.checkAndPut_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- compareTo(THBaseService.checkAndPut_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- compareTo(THBaseService.closeScanner_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- compareTo(THBaseService.closeScanner_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- compareTo(THBaseService.deleteMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- compareTo(THBaseService.deleteMultiple_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- compareTo(THBaseService.deleteSingle_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- compareTo(THBaseService.deleteSingle_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- compareTo(THBaseService.exists_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- compareTo(THBaseService.exists_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- compareTo(THBaseService.get_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- compareTo(THBaseService.get_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- compareTo(THBaseService.getMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- compareTo(THBaseService.getMultiple_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- compareTo(THBaseService.getScannerResults_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- compareTo(THBaseService.getScannerResults_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- compareTo(THBaseService.getScannerRows_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- compareTo(THBaseService.getScannerRows_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- compareTo(THBaseService.increment_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- compareTo(THBaseService.increment_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- compareTo(THBaseService.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- compareTo(THBaseService.mutateRow_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- compareTo(THBaseService.openScanner_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- compareTo(THBaseService.openScanner_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- compareTo(THBaseService.put_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- compareTo(THBaseService.put_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- compareTo(THBaseService.putMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- compareTo(THBaseService.putMultiple_result) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- compareTo(TIllegalArgument) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- compareTo(TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- compareTo(TIOError) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- compareTo(TMutation) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- compareTo(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- compareTo(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- compareTo(TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- compareTo(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- compareTo(TTimeRange) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- compareTo(ByteRange) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
Bitwise comparison of each byte in the array.
- compareTo(ByteBuffer, int, int, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
- compareTo(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- compareTo(byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Lexicographically compare two arrays.
- compareTo(WALKey) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- compareToCurrentToken(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
-
Compare only the bytes within the window of the current token
- compareWithoutRow(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
-
- CompatibilityFactory - Class in org.apache.hadoop.hbase
-
Class that will create many instances of classes provided by the hbase-hadoop{1|2}-compat jars.
- CompatibilityFactory() - Constructor for class org.apache.hadoop.hbase.CompatibilityFactory
-
This is a static only class don't let any instance be created.
- CompatibilitySingletonFactory - Class in org.apache.hadoop.hbase
-
Factory for classes supplied by hadoop compatibility modules.
- CompatibilitySingletonFactory() - Constructor for class org.apache.hadoop.hbase.CompatibilitySingletonFactory
-
This is a static only class don't let anyone create an instance.
- CompatibilitySingletonFactory.SingletonStorage - Enum in org.apache.hadoop.hbase
-
- compile() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
-
methods
- compile() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
- compile() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
Now that all the cells have been added, do the work to reduce them to a series of byte[]
fragments that are ready to be written to the output stream.
- compile() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
-
methods
- compile() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
-
- compileFamilies() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- compileMvccVersions() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- compileQualifiers() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- compilerInternals() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
-
- compileRows() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- compileTags() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- compileTimestamps() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- compileTypes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
The following "compile" methods do any intermediate work necessary to transform the cell
fragments collected during the writing phase into structures that are ready to write to the
outputStream.
- complete() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
Call to indicate that additional coprocessors further down the execution
chain do not need to be invoked.
- complete() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
For all time forward, do not throw an error because the process has completed.
- complete(Path) - Static method in class org.apache.hadoop.hbase.io.hfile.PrefetchExecutor
-
- complete() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
Marks the compaction as complete by setting total to current KV count;
Total KV count is an estimate, so there might be a discrepancy otherwise.
- COMPLETE_SEQUENCE_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- completeCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- completeCacheFlush(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Complete the cache flush.
- completeCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
It works by processing a compaction that's been written to disk.
- completeCompaction(Collection<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
It works by processing a compaction that's been written to disk.
- completed(Throwable) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
Called after that process() is completed.
- completed(Throwable) - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
Called after that process() is completed.
- completed(Throwable) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- completed(Throwable) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- completeMemstoreInsert(MultiVersionConsistencyControl.WriteEntry) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
- completeMemstoreInsertWithSeqNum(MultiVersionConsistencyControl.WriteEntry, SequenceId) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
- completeRegionMergeTransaction(RegionServerServices, HRegionInfo, HRegion, HRegion, RegionMergeCoordination.RegionMergeDetails, HRegion) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
Finish off merge transaction
- completeRegionMergeTransaction(RegionServerServices, HRegionInfo, HRegion, HRegion, RegionMergeCoordination.RegionMergeDetails, HRegion) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
- completeSnapshot(Path, Path, FileSystem) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Reset the manager to allow another snapshot to proceed
- completeSnapshot(HBaseProtos.SnapshotDescription, Path, Path, FileSystem) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Move the finished snapshot to its final, publicly visible directory - this marks the snapshot
as 'complete'.
- completeSplitTransaction(RegionServerServices, Region, Region, SplitTransactionCoordination.SplitTransactionDetails, Region) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
-
Finish off split transaction
- completeSplitTransaction(RegionServerServices, Region, Region, SplitTransactionCoordination.SplitTransactionDetails, Region) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
-
Finish off split transaction, transition the zknode
- completionCleanup(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- completionCleanup(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called when the procedure is marked as completed (success or rollback).
- completionCleanup(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
-
The procedure in execution completed.
- completionCleanup(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
-
- components - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- CompoundBloomFilter - Class in org.apache.hadoop.hbase.util
-
A Bloom filter implementation built on top of
ByteBloomFilter
,
encapsulating a set of fixed-size Bloom filters written out at the time of
HFile
generation into the data
block stream, and loaded on demand at query time.
- CompoundBloomFilter(DataInput, HFile.Reader) - Constructor for class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
De-serialization for compound Bloom filter metadata.
- CompoundBloomFilterBase - Class in org.apache.hadoop.hbase.util
-
- CompoundBloomFilterBase() - Constructor for class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- CompoundBloomFilterWriter - Class in org.apache.hadoop.hbase.util
-
Adds methods required for writing a compound Bloom filter to the data
section of an
HFile
to the
CompoundBloomFilter
class.
- CompoundBloomFilterWriter(int, float, int, int, boolean, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- CompoundConfiguration - Class in org.apache.hadoop.hbase
-
Do a shallow merge of multiple KV configuration pools.
- CompoundConfiguration() - Constructor for class org.apache.hadoop.hbase.CompoundConfiguration
-
Default Constructor.
- compress(byte[], Dictionary) - Method in interface org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.ByteStringCompressor
-
- COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- compressAfterEncoding(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- compressAlgo - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Filled when we read in the trailer.
- compressAndEncrypt(byte[]) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- compressAndEncrypt(byte[]) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
- COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- Compression - Class in org.apache.hadoop.hbase.io.compress
-
Compression related stuff.
- compression - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- compression - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- Compression.Algorithm - Enum in org.apache.hadoop.hbase.io.compress
-
Compression algorithms.
- COMPRESSION_CODEC_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- COMPRESSION_COMPACT - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- COMPRESSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- compressionByName(String) - Static method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- CompressionContext - Class in org.apache.hadoop.hbase.regionserver.wal
-
Context that holds the various dictionaries for compression in WAL.
- CompressionContext(Class<? extends Dictionary>, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.CompressionContext
-
- compressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Compression context to use reading.
- compressionContext - Variable in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
-
- compressionContext - Variable in class org.apache.hadoop.hbase.wal.WALKey
-
- CompressionTest - Class in org.apache.hadoop.hbase.util
-
Compression validation test.
- CompressionTest() - Constructor for class org.apache.hadoop.hbase.util.CompressionTest
-
- compressor - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- Compressor - Class in org.apache.hadoop.hbase.regionserver.wal
-
A set of static functions for running our custom WAL compression/decompression.
- Compressor() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.Compressor
-
- compressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- compressTags(OutputStream, byte[], int, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
-
Compress tags one by one and writes to the OutputStream.
- compressTags(OutputStream, ByteBuffer, int) - Method in class org.apache.hadoop.hbase.io.TagCompressionContext
-
Compress tags one by one and writes to the OutputStream.
- computeBitSize(long, double) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- computeCost(BaseLoadBalancer.Cluster, double) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
This is the main cost function.
- computeFilename(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
This is a convenience method that computes a new filename with a given
file-number.
- computeFoldableByteSize(long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Increases the given byte size of a Bloom filter until it can be folded by
the given factor.
- computeHDFSBlocksDistribution(Configuration, HTableDescriptor, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function to compute HDFS block distribution on demand
- computeHDFSBlocksDistribution(Configuration, HTableDescriptor, HRegionInfo, Path) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
This is a helper function to compute HDFS block distribution on demand
- computeHDFSBlocksDistribution(FileSystem) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Compute the HDFS Block Distribution for this StoreFile
- computeHDFSBlocksDistribution(FileSystem, FileStatus, long, long) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Compute HDFS blocks distribution of a given file, or a portion of the file
- computeMaxKeys(long, double, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
The maximum number of keys we can put into a Bloom filter of a certain
size to get the given error rate, with the given number of hash functions.
- ConcatenatedLists<T> - Class in org.apache.hadoop.hbase.util
-
A collection class that contains multiple sub-lists, which allows us to not copy lists.
- ConcatenatedLists() - Constructor for class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- ConcatenatedLists.Iterator - Class in org.apache.hadoop.hbase.util
-
- ConcatenatedLists.Iterator() - Constructor for class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
-
- CONCURRENT_HASHMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentHashMap
- CONCURRENT_HASHMAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentHashMap.Entry
- CONCURRENT_HASHMAP_SEGMENT - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentHashMap.Segment
- CONCURRENT_SKIPLISTMAP - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentSkipListMap
- CONCURRENT_SKIPLISTMAP_ENTRY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ConcurrentSkipListMap Entry
- ConcurrentIndex<K,V> - Class in org.apache.hadoop.hbase.util
-
A simple concurrent map of sets.
- ConcurrentIndex(Supplier<Set<V>>) - Constructor for class org.apache.hadoop.hbase.util.ConcurrentIndex
-
Creates an instance with a specified factory object for sets to be
associated with a given key.
- ConcurrentIndex(Comparator<V>) - Constructor for class org.apache.hadoop.hbase.util.ConcurrentIndex
-
Creates an instance using the DefaultValueSetFactory for sets,
which in turn creates instances of
ConcurrentSkipListSet
- concurrentVisitReferencedFiles(Configuration, FileSystem, SnapshotManifest, SnapshotReferenceUtil.StoreFileVisitor) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
- CONDITION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
- CONDITION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
- conf - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- conf - Variable in class org.apache.hadoop.hbase.client.HConnectable
-
- conf - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- conf - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- conf - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- conf - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- conf - Variable in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
-
- conf - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- conf - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- conf - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- conf - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
conf object
- conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
-
- conf - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
- conf - Variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- conf - Variable in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- conf - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- CONF_CONTEXT_ATTRIBUTE - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- CONF_SKIP_TMP - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
-
- CONFIG - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
Denotes class names that appear in user facing configuration files.
- config - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- configs - Variable in class org.apache.hadoop.hbase.CompoundConfiguration
-
- CONFIGURATION - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CONFIGURATION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- CONFIGURATION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
- CONFIGURATION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- CONFIGURATION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- CONFIGURATION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- ConfigurationManager - Class in org.apache.hadoop.hbase.conf
-
Maintains the set of all the classes which would like to get notified
when the Configuration is reloaded from the disk in the Online Configuration
Change mechanism, which lets you update certain configuration properties
on-the-fly, without having to restart the cluster.
- ConfigurationManager() - Constructor for class org.apache.hadoop.hbase.conf.ConfigurationManager
-
- configurationManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Configuration manager is used to register/deregister and notify the configuration observers
when the regionserver is notified that there was a change in the on disk configs.
- ConfigurationObserver - Interface in org.apache.hadoop.hbase.conf
-
Every class that wants to observe changes in Configuration properties,
must implement interface (and also, register itself with the
ConfigurationManager
object.
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
-
- configureCfRenaming(Configuration, Map<String, String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Sets a configuration property with key
Import.CF_RENAME_PROP
in conf that tells
the mapper how to rename column families.
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.FlushPolicy
-
Upon construction, this method will be called with the region to be governed.
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
- configureForRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
Upon construction, this method will be called with the region
to be governed.
- configureIncrementalLoad(Job, HTable) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
-
Deprecated.
Configure a MapReduce Job to perform an incremental load into the given
table.
- configureIncrementalLoad(Job, HTable) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- configureIncrementalLoad(Job, Table, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure a MapReduce Job to perform an incremental load into the given
table.
- configureIncrementalLoad(Job, HTableDescriptor, RegionLocator) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
Configure a MapReduce Job to perform an incremental load into the given
table.
- configureIncrementalLoadMap(Job, Table) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- configureInfoServer() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- configureInfoServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- configureJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder
-
Job configuration.
- configureJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SampleUploader
-
Job configuration.
- configureSplitTable(Job, TableName) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Sets split table in map-reduce job.
- ConfigUtil - Class in org.apache.hadoop.hbase.util
-
Some configuration related utilities
- ConfigUtil() - Constructor for class org.apache.hadoop.hbase.util.ConfigUtil
-
- confirmNodeOpening(ZooKeeperWatcher, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Confirm an existing unassigned node for the specified region which is
currently in the OPENING state to be still in the OPENING state on
the specified server.
- confirmRegionMergeTransaction(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, RegionMergeCoordination.RegionMergeDetails) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
Confirm that the region merge can be performed
- confirmRegionMergeTransaction(HRegionInfo, HRegionInfo, HRegionInfo, ServerName, RegionMergeCoordination.RegionMergeDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
- ConfServlet - Class in org.apache.hadoop.hbase.http.conf
-
A servlet to print out the running configuration data.
- ConfServlet() - Constructor for class org.apache.hadoop.hbase.http.conf.ConfServlet
-
- ConfServlet.BadFormatException - Exception in org.apache.hadoop.hbase.http.conf
-
- ConfServlet.BadFormatException(String) - Constructor for exception org.apache.hadoop.hbase.http.conf.ConfServlet.BadFormatException
-
- connect(HConnection) - Method in class org.apache.hadoop.hbase.client.HConnectable
-
- connect(Configuration) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
-
- connect(Configuration) - Method in interface org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
-
- connect() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
To repair region consistency, one must call connect() in order to repair
online state.
- connect(Configuration, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates a new connection to ZooKeeper, pulling settings and ensemble config
from the specified configuration object using methods from
ZKConfig
.
- connect(Configuration, String, Watcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- connect(Configuration, String, Watcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- connection - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- Connection - Interface in org.apache.hadoop.hbase.client
-
A cluster connection encapsulating lower level individual connections to actual servers and
a connection to zookeeper.
- connection - Variable in class org.apache.hadoop.hbase.client.HTable
-
- connection - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- connection - Variable in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- connection - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- connection - Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- ConnectionCache - Class in org.apache.hadoop.hbase.util
-
A utility to store user specific HConnections in memory.
- ConnectionCache(Configuration, UserProvider, int, int) - Constructor for class org.apache.hadoop.hbase.util.ConnectionCache
-
- ConnectionClosingException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the client believes that we are trying to communicate to has
been repeatedly unresponsive for a while.
- ConnectionClosingException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ConnectionClosingException
-
- ConnectionConfiguration - Class in org.apache.hadoop.hbase.client
-
Configuration parameters for the connection.
- ConnectionConfiguration() - Constructor for class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
Constructor
This is for internal testing purpose (using the default value).
- ConnectionFactory - Class in org.apache.hadoop.hbase.client
-
A non-instantiable class that manages creation of
Connection
s.
- ConnectionFactory() - Constructor for class org.apache.hadoop.hbase.client.ConnectionFactory
-
No public c.tors
- ConnectionId - Class in org.apache.hadoop.hbase.ipc
-
This class holds the address and the user ticket, etc.
- ConnectionId(User, String, InetSocketAddress) - Constructor for class org.apache.hadoop.hbase.ipc.ConnectionId
-
- connectionList - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- connections - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl
-
- ConnectionUtils - Class in org.apache.hadoop.hbase.client
-
Utility used by client connections.
- ConnectionUtils() - Constructor for class org.apache.hadoop.hbase.client.ConnectionUtils
-
- connectTO - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- Consistency - Enum in org.apache.hadoop.hbase.client
-
Consistency defines the expected consistency level for an operation.
- consistency - Variable in class org.apache.hadoop.hbase.client.Query
-
- CONSISTENCY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- CONSISTENCY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- consolidate() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- Constants - Interface in org.apache.hadoop.hbase.rest
-
Common constants for org.apache.hadoop.hbase.rest
- ConstantSizeRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A
RegionSplitPolicy
implementation which splits a region
as soon as any of its store files exceeds a maximum configurable
size.
- ConstantSizeRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
- constrainHttpMethods(Context) - Static method in class org.apache.hadoop.hbase.util.HttpServerUtil
-
Add constraints to a Jetty Context to disallow undesirable Http methods.
- Constraint - Interface in org.apache.hadoop.hbase.constraint
-
Apply a
Constraint
(in traditional database terminology) to a HTable.
- ConstraintException - Exception in org.apache.hadoop.hbase.constraint
-
Exception that a user defined constraint throws on failure of a
Put
.
- ConstraintException() - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- ConstraintException(String) - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- ConstraintException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.constraint.ConstraintException
-
- ConstraintProcessor - Class in org.apache.hadoop.hbase.constraint
-
- ConstraintProcessor() - Constructor for class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
Create the constraint processor.
- Constraints - Class in org.apache.hadoop.hbase.constraint
-
Utilities for adding/removing constraints from a table.
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- constructImpl(Class<? extends AbstractTemplateImpl>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- constructImpl() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- constructMaster(Class<? extends HMaster>, Configuration, CoordinatedStateManager) - Static method in class org.apache.hadoop.hbase.master.HMaster
-
Utility for constructing an instance of the passed HMaster class.
- constructOutputStream(DataOutput) - Static method in class org.apache.hadoop.hbase.io.DataOutputOutputStream
-
Construct an OutputStream from the given DataOutput.
- constructRegionServer(Class<? extends HRegionServer>, Configuration, CoordinatedStateManager) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Utility for constructing an instance of the passed HRegionServer class.
- consume() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
consume one available unit.
- consume(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
consume amount available units.
- consumeRead(long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Removes or add back some read amount to the quota.
- consumeRead(long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- consumerLoop(BlockingQueue<CallRunner>) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- consumeWrite(long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Removes or add back some write amount to the quota.
- consumeWrite(long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- contains(byte[]) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- contains(byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- contains(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- contains(Object) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- contains(Object) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- contains(byte[], int, int, ByteBuffer) - Method in interface org.apache.hadoop.hbase.util.BloomFilter
-
Check if the specified key is contained in the bloom filter.
- contains(Object) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- contains(byte[], int, int, ByteBuffer) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- contains(byte[], int, int, ByteBuffer, int, int, Hash, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- contains(byte[], byte) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- contains(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- contains(byte[], int, int, ByteBuffer) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- contains(Object) - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- contains(Object) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- containsAll(Collection<?>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- containsBlock(BlockCacheKey) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Whether the cache contains block with specified cacheKey
- containsColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks for existence of a value for the specified column (empty or not).
- containsColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks for existence of a value for the specified column (empty or not).
- containsEmptyColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains an empty value (a zero-length byte array).
- containsEmptyColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains an empty value (a zero-length byte array).
- containsIgnoreMvccVersion(Collection<? extends Cell>, Collection<? extends Cell>) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
Checks whether KeyValues from kvCollection2 are contained in kvCollection1.
- containsKey(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- containsKey(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Checks whether there is a value in the map for the specified key.
- containsKey(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- containsNonEmptyColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains a non-empty value (not a zero-length byte array).
- containsNonEmptyColumn(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Checks if the specified column contains a non-empty value (not a zero-length byte array).
- containsRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Returns true if the given inclusive range of rows is fully contained
by this region.
- containsRow(byte[]) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Return true if the given row falls in this region.
- containsValue(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- containsValue(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Checks whether this is a mapping which contains the specified value.
- containsValue(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- Context - Class in org.apache.hadoop.hbase.io.crypto
-
Crypto context.
- CONTEXT - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- control(String, long) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputController
-
Control the compaction throughput.
- control(String, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- control(String, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- controller - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- controller - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- controllerConnectionFailure(String, Throwable, String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
The connection to the rest of the procedure group (member and coordinator) has been
broken/lost/failed.
- controllerFactory - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- convert() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Convert a ClusterStatus to a protobuf ClusterStatus
- convert(ClusterStatusProtos.ClusterStatus) - Static method in class org.apache.hadoop.hbase.ClusterStatus
-
Convert a protobuf ClusterStatus to a ClusterStatus
- convert(HBaseProtos.ColumnFamilySchema) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- convert() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- convert(HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Convert a HRegionInfo to a RegionInfo
- convert(HBaseProtos.RegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Convert a RegionInfo to a HRegionInfo
- convert() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- convert(HBaseProtos.TableSchema) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
- convert() - Method in class org.apache.hadoop.hbase.io.Reference
-
- convert(FSProtos.Reference) - Static method in class org.apache.hadoop.hbase.io.Reference
-
- convert() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Convert a RegionState to an HBaseProtos.RegionState
- convert(ClusterStatusProtos.RegionState) - Static method in class org.apache.hadoop.hbase.master.RegionState
-
Convert a protobuf HBaseProtos.RegionState to a RegionState
- convert() - Method in enum org.apache.hadoop.hbase.master.RegionState.State
-
Convert to protobuf ClusterStatusProtos.RegionState.State
- convert(ClusterStatusProtos.RegionState.State) - Static method in enum org.apache.hadoop.hbase.master.RegionState.State
-
Convert a protobuf HBaseProtos.RegionState.State to a RegionState.State
- convert(Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Helper to convert the procedure to protobuf.
- convert(ProcedureProtos.Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Helper to convert the protobuf procedure.
- convert() - Method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
-
- convert() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- convert(ProcedureProtos.ProcedureStoreTracker.TrackerNode) - Static method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- convert(ProcedureProtos.Procedure) - Static method in class org.apache.hadoop.hbase.ProcedureInfo
-
Helper to convert the protobuf object.
- convert(DeserializationException) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- convertByteArrayToBoolean(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Converts a boolean expressed in a byte array to an actual boolean
- convertByteArrayToInt(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Converts an int expressed in a byte array to an actual int
- convertByteArrayToLong(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Converts a long expressed in a byte array to an actual long
- convertKvToByteBuffer(List<KeyValue>, boolean) - Static method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
Convert list of KeyValues to byte buffer.
- convertResult(MasterProtos.GetProcedureResultResponse) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
Convert the procedure result response to a specified type.
- convertThrowableToIOE(Throwable, String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- convertToBigInteger(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Returns the BigInteger represented by the byte array
- convertToByte(BigInteger, int) - Static method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Returns the bytes corresponding to the BigInteger
- convertToByte(BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Returns the bytes corresponding to the BigInteger
- convertToBytes(BigInteger[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Returns an array of bytes corresponding to an array of BigIntegers
- convertToProcedureProto(ProcedureInfo) - Static method in class org.apache.hadoop.hbase.ProcedureInfo
-
- CoordinatedStateException - Exception in org.apache.hadoop.hbase
-
Thrown by operations requiring coordination state access or manipulation
when internal error within coordination engine (or other internal implementation) occurs.
- CoordinatedStateException() - Constructor for exception org.apache.hadoop.hbase.CoordinatedStateException
-
- CoordinatedStateException(String) - Constructor for exception org.apache.hadoop.hbase.CoordinatedStateException
-
- CoordinatedStateException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.CoordinatedStateException
-
- CoordinatedStateException(Throwable) - Constructor for exception org.apache.hadoop.hbase.CoordinatedStateException
-
- CoordinatedStateManager - Interface in org.apache.hadoop.hbase
-
Implementations of this interface will keep and return to clients
implementations of classes providing API to execute
coordinated operations.
- CoordinatedStateManagerFactory - Class in org.apache.hadoop.hbase
-
- CoordinatedStateManagerFactory() - Constructor for class org.apache.hadoop.hbase.CoordinatedStateManagerFactory
-
- coordinator - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
- COPROC - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
- Coprocessor - Interface in org.apache.hadoop.hbase
-
Coprocessor interface.
- Coprocessor.State - Enum in org.apache.hadoop.hbase
-
Lifecycle state of a given coprocessor instance.
- COPROCESSOR_EXECUTION_STATISTICS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- COPROCESSOR_EXECUTION_STATISTICS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- CoprocessorClassLoader - Class in org.apache.hadoop.hbase.util
-
ClassLoader used to load classes for Coprocessor instances.
- CoprocessorEnvironment - Interface in org.apache.hadoop.hbase
-
Coprocessor environment state.
- CoprocessorException - Exception in org.apache.hadoop.hbase.coprocessor
-
Thrown if a coprocessor encounters any exception.
- CoprocessorException() - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Default Constructor
- CoprocessorException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Constructor with a Class object and exception message.
- CoprocessorException(String) - Constructor for exception org.apache.hadoop.hbase.coprocessor.CoprocessorException
-
Constructs the exception and supplies a string as the message
- CoprocessorHConnection - Class in org.apache.hadoop.hbase.client
-
Connection to an HTable from within a Coprocessor.
- CoprocessorHConnection(ClusterConnection, HRegionServer) - Constructor for class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
Deprecated.
delegate is not used
- CoprocessorHConnection(HRegionServer) - Constructor for class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
Constructor that uses server configuration
- CoprocessorHConnection(Configuration, HRegionServer) - Constructor for class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
Constructor that accepts custom configuration
- CoprocessorHost<E extends CoprocessorEnvironment> - Class in org.apache.hadoop.hbase.coprocessor
-
Provides the common setup framework and runtime services for coprocessor
invocation from HBase services.
- CoprocessorHost(Abortable) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- CoprocessorHost.Environment - Class in org.apache.hadoop.hbase.coprocessor
-
Encapsulation of the environment of each coprocessor
- CoprocessorHost.Environment(Coprocessor, int, int, Configuration) - Constructor for class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Constructor
- CoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
-
Base class which provides clients with an RPC connection to
call coprocessor endpoint Service
s.
- CoprocessorRpcChannel() - Constructor for class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- coprocessors - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Ordered set of loaded coprocessors with lock
- COPROCESSORS_ENABLED_CONF_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- COPROCESSORS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- coprocessorService() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates and returns a RpcChannel
instance connected to the active
master.
- coprocessorService(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates and returns a RpcChannel
instance
connected to the passed region server.
- coprocessorService() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates and returns a RpcChannel
instance
connected to the active master.
- coprocessorService(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates and returns a RpcChannel
instance
connected to the passed region server.
- coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates and returns a RpcChannel
instance connected to the
table region containing the specified row.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates an instance of the given
Service
subclass for each table
region spanning the range from the
startKey
row to
endKey
row (inclusive), and
invokes the passed
Batch.Call.call(T)
method
with each
Service
instance.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates an instance of the given
Service
subclass for each table
region spanning the range from the
startKey
row to
endKey
row (inclusive), and
invokes the passed
Batch.Call.call(T)
method
with each
Service
instance.
- coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- coprocessorService(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Creates and returns a RpcChannel
instance connected to the
table region containing the specified row.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Creates an instance of the given
Service
subclass for each table
region spanning the range from the
startKey
row to
endKey
row (inclusive), and
invokes the passed
Batch.Call.call(T)
method
with each
Service
instance.
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Creates an instance of the given
Service
subclass for each table
region spanning the range from the
startKey
row to
endKey
row (inclusive), and
invokes the passed
Batch.Call.call(T)
method
with each
Service
instance.
- CoprocessorService - Interface in org.apache.hadoop.hbase.coprocessor
-
- coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- copy(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Copy the byte array given in parameter and return an instance
of a new byte array with the same length and the same content.
- copy(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Copy the byte array given in parameter and return an instance
of a new byte array with the same length and the same content.
- copyBufferToNewArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
-
- copyBufferToStream(OutputStream, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy data from a buffer to an output stream.
- copyBytes() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Returns a copy of the bytes referred to by this writable
- copyDeadServersSince(long) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Extract all the servers dead since a given time, and sort them.
- copyFamilyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- copyFrom(Result) - Method in class org.apache.hadoop.hbase.client.Result
-
Copy another Result into this one.
- copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy from one buffer to another from given offset.
- copyFromBufferToBuffer(ByteBuffer, ByteBuffer, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy from one buffer to another from given offset.
- copyFromNext(BufferedDataBlockEncoder.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerState
-
- copyFromNext(BufferedDataBlockEncoder.SeekerState) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder.FastDiffSeekerState
-
- copyFromStreamToBuffer(ByteBuffer, DataInputStream, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy the given number of bytes from the given stream and put it at the
current position of the given buffer, updating the position in the buffer.
- CopyKeyDataBlockEncoder - Class in org.apache.hadoop.hbase.io.encoding
-
Just copy data, do not do any kind of compression.
- CopyKeyDataBlockEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- copyKeyToNewByteBuffer(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
The position will be set to the beginning of the new ByteBuffer
- COPYONWRITE_ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for CopyOnWriteArrayList
- COPYONWRITE_ARRAYSET - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for CopyOnWriteArraySet
- copyQualifierTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- copyRowTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
copyTo
- copyServerNames() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- copySnapshotForScanner(Configuration, FileSystem, Path, Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper
-
Copy the snapshot files for a snapshot scanner, discards meta changes.
- CopyTable - Class in org.apache.hadoop.hbase.mapreduce
-
Tool used to copy a table to another one which can be on a different setup.
- CopyTable(Configuration) - Constructor for class org.apache.hadoop.hbase.mapreduce.CopyTable
-
- copyTagTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Copies the tags info into the tag portion of the cell
- copyToNewArrays(Collection<ByteRange>) - Static method in class org.apache.hadoop.hbase.util.ByteRangeUtils
-
- copyToNewByteArray(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
- copyToNewByteBuffer(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
The position will be set to the beginning of the new ByteBuffer
- copyToNewKeyValue(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
copy key only
- copyValueTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- copyWritable(Writable, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Copy one Writable to another.
- copyWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Copy one Writable to another.
- CORRUPT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CorruptedSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
Exception thrown when the found snapshot info from the filesystem is not valid
- CorruptedSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
- CorruptedSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
Snapshot was corrupt for some reason
- CorruptedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.CorruptedSnapshotException
-
- CorruptedWALProcedureStoreException - Exception in org.apache.hadoop.hbase.procedure2.store.wal
-
Thrown when a procedure WAL is corrupted
- CorruptedWALProcedureStoreException() - Constructor for exception org.apache.hadoop.hbase.procedure2.store.wal.CorruptedWALProcedureStoreException
-
default constructor
- CorruptedWALProcedureStoreException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.store.wal.CorruptedWALProcedureStoreException
-
Constructor
- CorruptHFileException - Exception in org.apache.hadoop.hbase.io.hfile
-
This exception is thrown when attempts to read an HFile fail due to corruption or truncation
issues.
- CorruptHFileException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.io.hfile.CorruptHFileException
-
- CorruptHFileException(String) - Constructor for exception org.apache.hadoop.hbase.io.hfile.CorruptHFileException
-
- COUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- countDown(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
-
- countDown(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- Counter - Class in org.apache.hadoop.hbase.util
-
High scalable counter.
- Counter() - Constructor for class org.apache.hadoop.hbase.util.Counter
-
- Counter(long) - Constructor for class org.apache.hadoop.hbase.util.Counter
-
- countOfBytesInRemoteResults - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of bytes in Result objects from remote region servers
- countOfBytesInResults - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of bytes in Result objects from region servers
- countOfNSRE - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of NotServingRegionException caught
- countOfRegions - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of regions
- countOfRegionServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- countOfRemoteRPCcalls - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of remote RPC calls
- countOfRemoteRPCRetries - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of remote RPC retries
- countOfRPCcalls - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of RPC calls
- countOfRPCRetries - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
number of RPC retries
- countPerRow - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- CP_HTD_ATTR_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_VALUE_PARAM_KEY_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_VALUE_PARAM_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_VALUE_PARAM_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
- CP_HTD_ATTR_VALUE_PATTERN - Static variable in class org.apache.hadoop.hbase.HConstants
-
Pattern that matches a coprocessor specification.
- create(Configuration) - Static method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Create an archive tracker for the passed in server
- create(Configuration) - Static method in class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory
-
- create(List<Cell>) - Static method in class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified List of KeyValues.
- create(List<Cell>, Boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(List<Cell>, Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(List<Cell>, Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(Cell[]) - Static method in class org.apache.hadoop.hbase.client.Result
-
Instantiate a Result with the specified array of KeyValues.
- create(Cell[], Boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(Cell[], Boolean, boolean, boolean) - Static method in class org.apache.hadoop.hbase.client.Result
-
- create(Configuration) - Static method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
-
- create() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Creates a Configuration with HBase resources
- create(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
- create() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- create(Configuration, FileSystem, Path, HRegionInfo, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink
- create(Configuration, FileSystem, Path, HRegionInfo, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink
- create(Configuration, FileSystem, Path, TableName, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink
- create(Configuration, FileSystem, Path, TableName, String, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink
- create(String, MetricsHBaseServerWrapper) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactoryImpl
-
- create(DataInput) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- create(int, DataInput) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Create a KeyValue reading length
from in
- create(String, String, String, long, String) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- create(String, String, String, long, KeyValue.Type, String) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, String) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
Deprecated.
- create(byte[], int, int, byte[], int, int, byte[], int, int, long, byte[], int, int, List<Tag>) - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- create(MetricsMasterWrapper) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSourceFactory
-
- create(MetricsMasterWrapper) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl
-
- create(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- create(String) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- create(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- create(RegionServerServices, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputControllerFactory
-
- create(HRegion, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
-
Create the FlushPolicy configured for the given table.
- create(Configuration, FlushRequester, Server) - Static method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- create(Region, Region, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
-
Create a merge transaction
- create(HRegion, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
Create the RegionSplitPolicy configured for the given table.
- create(Configuration, PriorityFunction, Abortable) - Method in interface org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory
-
- create(Configuration, PriorityFunction) - Method in interface org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory
-
Deprecated.
- create(Configuration, PriorityFunction) - Method in class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
-
Deprecated.
- create(Configuration, PriorityFunction, Abortable) - Method in class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
-
- create(Region, byte[]) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
-
Create a split transaction
- create(Store, Configuration, KeyValue.KVComparator) - Static method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Create the StoreEngine configured for the given Store.
- create(Configuration, String, CompressionContext) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
Create and setup a
WALCellCodec
from the
cellCodecClsName
and
CompressionContext, if
cellCodecClsName
is specified.
- create(Configuration, CompressionContext) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
Create and setup a
WALCellCodec
from the
CompressionContext.
- create(UserGroupInformation) - Static method in class org.apache.hadoop.hbase.security.User
-
Wraps an underlying UserGroupInformation
instance.
- create(UserGroupInformation) - Method in class org.apache.hadoop.hbase.security.UserProvider
-
Wraps an underlying UserGroupInformation
instance.
- create(Configuration, FileSystem, Path, HBaseProtos.SnapshotDescription, ForeignExceptionSnare) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Return a SnapshotManifest instance, used for writing a snapshot.
- create(FileSystem, Path, FsPermission, InetSocketAddress[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Create the specified file on the filesystem.
- create(FileSystem, Path, FsPermission, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Create the specified file on the filesystem.
- create() - Method in class org.apache.hadoop.hbase.util.RetryCounterFactory
-
- create(A, B, C) - Static method in class org.apache.hadoop.hbase.util.Triple
-
- create(String, byte[], List<ACL>, CreateMode) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
NONSEQUENTIAL create is idempotent operation.
- CREATE_TABLE_ADD_TO_META_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableState
-
CREATE_TABLE_ADD_TO_META = 3;
- CREATE_TABLE_ASSIGN_REGIONS_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableState
-
CREATE_TABLE_ASSIGN_REGIONS = 4;
- CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- CREATE_TABLE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- CREATE_TABLE_POST_OPERATION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableState
-
CREATE_TABLE_POST_OPERATION = 6;
- CREATE_TABLE_PRE_OPERATION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableState
-
CREATE_TABLE_PRE_OPERATION = 1;
- CREATE_TABLE_UPDATE_DESC_CACHE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableState
-
CREATE_TABLE_UPDATE_DESC_CACHE = 5;
- CREATE_TABLE_WRITE_FS_LAYOUT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableState
-
CREATE_TABLE_WRITE_FS_LAYOUT = 2;
- CREATE_TIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- CREATE_TIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- CREATE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
-
CREATE = 3;
- createACL(ZooKeeperWatcher, String, boolean) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- createAndAddPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
Attempt to connect to a new remote slave cluster.
- createAndFailSilent(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node, iff the node does not exist.
- createAndFailSilent(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node containing specified data, iff the node does not exist.
- createAndFailSilent(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- createAndGet(ZooKeeperWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
Creates the singleton instance, if not yet present, and returns the same.
- createAndPrepare(T, ObserverContext<T>) - Static method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
Instantiates a new ObserverContext instance if the passed reference is
null
and sets the environment in the new or existing instance.
- createAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node with the specified data and watches it.
- createAnother() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Creates another similar Bloom filter.
- createBaseListener(Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Create a required listener for the Jetty instance listening on the port
provided.
- createBlockingRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- createBlockingRpcChannel(ServerName, User, int) - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
-
Creates a "channel" that can be used by a blocking protobuf service.
- createBloomKey(byte[], int, int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
Create a key for a row-column Bloom filter.
- createBloomKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Create a key for a row-column Bloom filter.
- createBloomKey(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
Prepare an ordered pair of row and qualifier to be compared using
KeyValue.KeyComparator.
- createBottomReference(byte[]) - Static method in class org.apache.hadoop.hbase.io.Reference
-
- createBulkLoadEvent(HRegionInfo, WALProtos.BulkLoadDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
Create a bulk loader WALEdit
- createBySize(int, double, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Creates a Bloom filter of the given size.
- createCell(byte[], byte[], byte[], long, byte, byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[], byte[], long, byte, byte[], long) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[], byte[], long, byte, byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[], byte[], byte[], long, KeyValue.Type, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCell(byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Create a Cell with specific row.
- createCell(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Create a Cell with specific row and value.
- createCell(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Create a Cell with specific row.
- createCellScanner(List<? extends CellScannable>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCellScanner(Iterable<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCellScanner(Iterator<Cell>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCellScanner(Cell[]) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- createCellScanner(NavigableMap<byte[], List<Cell>>) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Flatten the map of cells out under the CellScanner
- createCellScanner(byte[]) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
-
Create a cell scanner
- createCellScanner(Codec, CompressionCodec, byte[]) - Method in class org.apache.hadoop.hbase.ipc.IPCUtil
-
- createCellScanner(Codec, CompressionCodec, byte[], int, int) - Method in class org.apache.hadoop.hbase.ipc.IPCUtil
-
- createCleanupScheduledChore(Stoppable) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
Creates a scheduled chore that is used to clean up old nonces.
- createClient(Configuration, String) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
-
Creates a new RpcClient by the class defined in the configuration or falls back to
RpcClientImpl
- createClient(Configuration, String, SocketAddress) - Static method in class org.apache.hadoop.hbase.ipc.RpcClientFactory
-
Creates a new RpcClient by the class defined in the configuration or falls back to
RpcClientImpl
- createClosestRowBefore(byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientScanner
-
Create the closest row before the specified row
- createCluster(List<ServerName>, Collection<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- createClusterConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Create a 'smarter' HConnection, one that is capable of by-passing RPC if the request is to
the local server.
- createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
-
- createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Creates an instance of a compaction context specific to this engine.
- createCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
-
- createCompaction(HRegionInfo, WALProtos.CompactionDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
Create a compaction WALEdit
- createComparator(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Parses a comparator of the form comparatorType:comparatorValue form and returns a comparator
- createComparator(String) - Static method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- createCompareOp(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Takes a compareOperator symbol as a byte array and returns the corresponding CompareOperator
- createCompleteResult(List<Result>) - Static method in class org.apache.hadoop.hbase.client.Result
-
Forms a single result from the partial results in the partialResults list.
- createComponents(Configuration, Store, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
-
- createComponents(Configuration, Store, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
Create the StoreEngine's components.
- createComponents(Configuration, Store, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
-
- createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- createConnection() - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using default HBaseConfiguration.
- createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.ConnectionFactory
-
Create a new Connection instance using the passed conf
instance.
- createConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- createConnection(Configuration, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- createConnection(Configuration, User) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- createConnection(Configuration, ExecutorService, User) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- createConnection(ConnectionId, Codec, CompressionCodec) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl
-
Creates a connection.
- createContextName(String) - Static method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceFactory
-
From the name of the class that's starting up create the
context that an IPC source should register itself.
- createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- createDecryptionStream(InputStream) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- createDecryptionStream(InputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a decrypting input stream given a context and IV
- createDecryptionStream(InputStream, Decryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a decrypting output stream given an initialized decryptor
- createDecryptionStream(InputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Create a stream for decryption
- createDefaultChannelConnector() - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
- createDeleteBloomAtWrite(Configuration, CacheConfig, int, HFile.Writer) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Creates a new Delete Family Bloom filter at the time of
StoreFile
writing.
- createDestinationServersList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Creates a list of possible destinations for a region.
- createDestinationServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- createDigestSaslClient(String[], String, CallbackHandler) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- createDigestSaslClient(String[], String, CallbackHandler) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
-
Create a Digest Sasl client
- createEmptyRequest(StripeCompactionPolicy.StripeInformationProvider, CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- createEncoder(String) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- createEncryptionStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- createEncryptionStream(OutputStream, Context, byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create an encrypting output stream given a context and IV
- createEncryptionStream(OutputStream, Encryptor) - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create an encrypting output stream given an initialized encryptor
- createEncryptionStream(OutputStream) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Create a stream for encryption
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Called when a new Coprocessor class is loaded
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.master.MasterCoprocessorHost
-
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerCoprocessorHost
-
- createEnvironment(Class<?>, Coprocessor, int, int, Configuration) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCoprocessorHost
-
- createEphemeralNodeAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Set the specified znode to be an ephemeral node carrying the specified
data.
- createExceptionString(Class) - Static method in class org.apache.hadoop.hbase.CompatibilityFactory
-
- createExecutor(Configuration, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- createFileScanners(Collection<StoreFile>, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Creates file scanners for compaction.
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FamilyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FilterBase
-
Given the filter's arguments it constructs the filter
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PageFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.QualifierFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.RowFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.filter.ValueFilter
-
- createFirstDeleteFamilyOnRow(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a Delete Family KeyValue for the specified row and family that would
be smaller than all other possible Delete Family KeyValues that have the
same row and family.
- createFirstKeyInIncrementedRow(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Increment the row bytes and clear the other fields
- createFirstKeyInNextRow(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Append single byte 0x00 to the end of the input row key
- createFirstOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- createFirstOnRow(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- createFirstOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- createFirstOnRow(byte[], int, short) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue that is smaller than all other possible KeyValues
for the given row.
- createFirstOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue that is smaller than all other possible KeyValues
for the given row.
- createFirstOnRow(byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Creates a KeyValue that is smaller than all other KeyValues that
are older than the passed timestamp.
- createFirstOnRow(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue for the specified row, family and qualifier that would be
smaller than all other possible KeyValues that have the same row,family,qualifier.
- createFirstOnRow(byte[], byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
- createFirstOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue for the specified row, family and qualifier that would be
smaller than all other possible KeyValues that have the same row,
family, qualifier.
- createFirstOnRow(byte[], byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue for the specified row, family and qualifier that would be
smaller than all other possible KeyValues that have the same row,
family, qualifier.
- createFirstOnRow(byte[], int, byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue for the specified row, family and qualifier that would be
smaller than all other possible KeyValues that have the same row,
family, qualifier.
- createFirstOnRowColTS(Cell, long) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Creates the first KV with the row/family/qualifier of this KV and the given
timestamp.
- createFirstOnRowColTS(KeyValue, long) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Creates the first KV with the row/family/qualifier of this KV and the
given timestamp.
- createFlushContext(long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- createFlushContext(long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- createFlushWALEdit(HRegionInfo, WALProtos.FlushDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- createFromFileInfo(HFile.FileInfo) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- createFromHFileLink(Configuration, FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink starting from a hfileLink name
- createFromHFileLink(Configuration, FileSystem, Path, String, boolean) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink starting from a hfileLink name
- createFromMeta(DataInput, HFile.Reader) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Instantiates the correct Bloom filter class based on the version provided
in the meta block data.
- createFsLayout(MasterProcedureEnv, HTableDescriptor, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- createFsLayout(MasterProcedureEnv, HTableDescriptor, List<HRegionInfo>, CreateTableProcedure.CreateHdfsRegions) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- createGeneralBloomAtWrite(Configuration, CacheConfig, BloomType, int, HFile.Writer) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
Creates a new general (Row or RowCol) Bloom filter at the time of
StoreFile
writing.
- createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
Create a key by concatenating multiple column values.
- createGroupKey(byte[][]) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Create a key by concatenating multiple column values.
- createHDFSRegionDir(Configuration, HRegionInfo, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
Creates, flushes, and closes a new region.
- createHdfsRegions(MasterProcedureEnv, Path, TableName, List<HRegionInfo>) - Method in interface org.apache.hadoop.hbase.master.procedure.CreateTableProcedure.CreateHdfsRegions
-
- createHFileContext(FSDataInputStreamWrapper, long, HFileSystem, Path, FixedFileTrailer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- createHFileContext(FSDataInputStreamWrapper, long, HFileSystem, Path, FixedFileTrailer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
-
- createHFileCorruptionChecker(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- createHFileLinkName(HRegionInfo, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink name
- createHFileLinkName(TableName, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create a new HFileLink name
- createHostAndPortStr(String, int) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, WAL, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, WAL, boolean, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(HRegionInfo, Path, Path, Configuration, HTableDescriptor, WAL, boolean, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Convenience method creating new HRegions.
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor, WAL) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- createHRegionInfos(HTableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
- createHTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
- createHTableInterface(Configuration, byte[]) - Method in class org.apache.hadoop.hbase.client.HTableFactory
-
Deprecated.
- createHTableInterface(Configuration, byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterfaceFactory
-
Deprecated.
Creates a new HTableInterface.
- createIdentifier() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- createInetSocketAddressFromHostAndPortStr(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- createInProgressTag(Path, FileSystem) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Create in-progress tag under .tmp of in-progress snapshot
- createKerberosSaslClient(String[], String, String) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
- createKerberosSaslClient(String[], String, String) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
-
Create Kerberos client
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- createKey() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- createKeyOnly(boolean) - Method in class org.apache.hadoop.hbase.KeyValue
-
Creates a new KeyValue that only contains the key portion (the value is
set to be null).
- createKeyValueFromKey(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- createKeyValueFromKey(ByteBuffer) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- createKeyValueFromKey(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- createLastOnRow(byte[], int, int, byte[], int, int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Create a KeyValue for the specified row, family and qualifier that would be
larger than or equal to all other possible KeyValues that have the same
row, family, qualifier.
- createLastOnRow(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Creates a keyValue for the specified keyvalue larger than or equal to all other possible
KeyValues that have the same row, family, qualifer.
- createLastOnRow(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
Creates a KeyValue that is last on the specified row id.
- createLastOnRowCol(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
- createLatch() - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- createLease(String, int, LeaseListener) - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Create a lease and insert it to the map of leases.
- createMasterThread(Configuration, CoordinatedStateManager, Class<? extends HMaster>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
- createMaxByteArray(int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Create a max byte array with the specified max byte count
- createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create a new namespace
- createNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create a new namespace
- createNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createNamespace(RpcController, MasterProtos.CreateNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- createNamespace(NamespaceDescriptor) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Create a new namespace
- createNamespace(RpcController, MasterProtos.CreateNamespaceRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- createNamespace(RpcController, MasterProtos.CreateNamespaceRequest, RpcCallback<MasterProtos.CreateNamespaceResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc CreateNamespace(.CreateNamespaceRequest) returns (.CreateNamespaceResponse);
- createNamespace(RpcController, MasterProtos.CreateNamespaceRequest, RpcCallback<MasterProtos.CreateNamespaceResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc CreateNamespace(.CreateNamespaceRequest) returns (.CreateNamespaceResponse);
- createNamespace(RpcController, MasterProtos.CreateNamespaceRequest, RpcCallback<MasterProtos.CreateNamespaceResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- createNodeClosing(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates a new unassigned node in the CLOSING state for the specified
region.
- createNodeIfNotExistsAndWatch(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified znode to be a persistent node carrying the specified
data.
- createNodeIfNotExistsNoWatch(ZooKeeperWatcher, String, byte[], CreateMode) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified znode with the specified data but does not watch it.
- createNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates a new unassigned node in the OFFLINE state for the specified region.
- createNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, EventType) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
- createNonRecursive(Path, boolean, int, short, long, Progressable) - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
The org.apache.hadoop.fs.FilterFileSystem does not yet support
createNonRecursive.
- createOrForceNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates or force updates an unassigned node to the OFFLINE state for the
specified region.
- createOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.io.compress.ReusableStreamGzipCodec
-
- createOutputStream(Configuration, FileSystem, Path, InetSocketAddress[]) - Static method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
A helper method to create HFile output streams in constructors
- createPassword(AuthenticationTokenIdentifier) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- createPath(TableName, String, String, String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Create an HFileLink relative path for the table/region/family/hfile location
- createPlainCompressionStream(OutputStream, Compressor) - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
Creates a compression stream without any additional wrapping into
buffering streams.
- createPool() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- createProcedureInfo(Procedure, NonceKey) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Helper to create the ProcedureInfo from Procedure.
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- createProtobufOutput() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- createProtobufOutput() - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
-
- createReader(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- createReader(FileSystem, Path, CacheConfig, Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- createReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- createReader(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- createReader(FileSystem, Path, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Create a reader for the WAL.
- createReader(FileSystem, Path, CancelableProgressable, boolean) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- createReader(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
Create a reader for the given path, accept custom reader classes from conf.
- createReaderIgnoreCustomClass(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
Create a reader for the given path, ignore custom reader classes from conf.
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
Deprecated.
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Builds a TableRecordReader.
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- createRecoveredEditsWriter(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
should be package-private, visible for recovery testing.
- createRegion(MetricsRegionWrapper) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Create a MetricsRegionSource from a MetricsRegionWrapper.
- createRegion(MetricsRegionWrapper) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
-
- createRegion(Configuration, Path, Path, HTableDescriptor, HRegionInfo, ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegionEventWALEdit(HRegionInfo, WALProtos.RegionEventDescriptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- createRegionLoad(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createRegionName(TableName, byte[], long, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], String, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], long, int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionName(TableName, byte[], byte[], int, boolean) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Make a region name of passed parameters.
- createRegionOnFileSystem(Configuration, FileSystem, Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Create a new Region on file-system.
- createRegions(Configuration, Path, HTableDescriptor, HRegionInfo[]) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegions(Configuration, Path, HTableDescriptor, HRegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegions(Configuration, Path, Path, HTableDescriptor, HRegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegions(ThreadPoolExecutor, Configuration, Path, Path, HTableDescriptor, HRegionInfo[], ModifyRegionUtils.RegionFillTask) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Create new set of regions on the specified file-system.
- createRegionServerStatusStub() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Get the current master from ZooKeeper and open the RPC connection to it.
- createRegionServerThread(Configuration, CoordinatedStateManager, Class<? extends HRegionServer>, int) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
- createRegionState(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Add a region to RegionStates.
- createRegionState(HRegionInfo, RegionState.State, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Add a region to RegionStates with the specified state.
- createRegionStates(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Add a list of regions to RegionStates.
- createRegionTransition(EventType, byte[], ServerName) - Static method in class org.apache.hadoop.hbase.RegionTransition
-
- createRegionTransition(EventType, byte[], ServerName, byte[]) - Static method in class org.apache.hadoop.hbase.RegionTransition
-
- createRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
-
Creates a "channel" that can be used by a protobuf service.
- createRpcServices() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createRpcServices() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- createRPCStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- createScanner(Store, List<StoreFileScanner>, ScanType, long, long) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- createScanner(Store, List<StoreFileScanner>, long, long, byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- createSecretKey(byte[]) - Static method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
-
Is this the correct handling of an illegal comparator? How to prevent that from getting all
the way to this point.
- createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Create a HFileBlock seeker which find KeyValues within a block.
- createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- createSeeker(KeyValue.KVComparator, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- createServer(MetricsRegionServerWrapper) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactory
-
Given a wrapper create a MetricsRegionServerSource.
- createServer(MetricsRegionServerWrapper) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl
-
- createServerSocket(int) - Method in class org.apache.hadoop.hbase.SslRMIServerSocketFactorySecure
-
- createSetData(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Set data into node creating node if it doesn't yet exist.
- createShortCircuitConnection(Configuration, ExecutorService, User, ServerName, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Creates a short-circuit connection that can bypass the RPC layer (serialization,
deserialization, networking, etc..) when talking to a local server.
- createShortCircuitHConnection(Connection, ServerName, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Deprecated.
- CreateSnapshot - Class in org.apache.hadoop.hbase.snapshot
-
This is a command line class that will snapshot a given table.
- CreateSnapshot() - Constructor for class org.apache.hadoop.hbase.snapshot.CreateSnapshot
-
- createSocket(String, int) - Method in class org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure
-
- createSSLEngine() - Method in class org.apache.hadoop.hbase.jetty.SslSelectChannelConnectorSecure
-
- createStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapred.RowCounter
-
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.CellCounter
-
Sets up the actual job.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.CopyTable
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Export
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication
-
Sets up the actual job.
- createSubmittableJob(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.RowCounter
-
Sets up the actual job.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer
-
Sets up the actual job.
- createSubprocedure(String, byte[]) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
This is separated from execution so that we can detect and handle the case where the
subprocedure is invalid and inactionable due to bad info (like DISABLED snapshot type being
sent here)
- createTable(HTableDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table.
- createTable(HTableDescriptor, byte[], byte[], int) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table with the specified number of regions.
- createTable(HTableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table with an initial set of empty regions defined by the specified split keys.
- createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates a new table.
- createTable(HTableDescriptor, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates a new table with the specified number of regions.
- createTable(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates a new table with an initial set of empty regions defined by the
specified split keys.
- createTable(HTableDescriptor, byte[][], long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- createTable(RpcController, MasterProtos.CreateTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- createTable(HTableDescriptor, byte[][], long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Create a table using the given table definition.
- createTable(RpcController, MasterProtos.CreateTableRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- createTable(RpcController, MasterProtos.CreateTableRequest, RpcCallback<MasterProtos.CreateTableResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc CreateTable(.CreateTableRequest) returns (.CreateTableResponse);
- createTable(RpcController, MasterProtos.CreateTableRequest, RpcCallback<MasterProtos.CreateTableResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc CreateTable(.CreateTableRequest) returns (.CreateTableResponse);
- createTable(RpcController, MasterProtos.CreateTableRequest, RpcCallback<MasterProtos.CreateTableResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
Creates a new table.
- createTable(ByteBuffer, List<ColumnDescriptor>, AsyncMethodCallback<Hbase.AsyncClient.createTable_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- createTable(ByteBuffer, List<ColumnDescriptor>, AsyncMethodCallback<Hbase.AsyncClient.createTable_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- createTable(ByteBuffer, List<ColumnDescriptor>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Create a table with the specified column families.
- createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- createTableAsync(HTableDescriptor, byte[][]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates a new table but does not block and wait for it to come online.
- createTableAsync(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates a new table but does not block and wait for it to come online.
- createTableDescriptor(HTableDescriptor) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create new HTableDescriptor in HDFS.
- createTableDescriptor(HTableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create new HTableDescriptor in HDFS.
- createTableDescriptorForTableDirectory(Path, HTableDescriptor, boolean) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Create a new HTableDescriptor in HDFS in the specified table directory.
- CreateTableHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handler to create a table.
- CreateTableHandler(Server, MasterFileSystem, HTableDescriptor, Configuration, HRegionInfo[], MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- createTableLockManager(Configuration, ZooKeeperWatcher, ServerName) - Static method in class org.apache.hadoop.hbase.master.TableLockManager
-
Creates and returns a TableLockManager according to the configuration
- CreateTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
- CreateTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- CreateTableProcedure(MasterProcedureEnv, HTableDescriptor, HRegionInfo[]) - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- CreateTableProcedure(MasterProcedureEnv, HTableDescriptor, HRegionInfo[], ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- CreateTableProcedure.CreateHdfsRegions - Interface in org.apache.hadoop.hbase.master.procedure
-
- createTempName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Generate a unique temporary Path.
- createTempName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Generate a unique temporary Path.
- createThriftOneSource() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
-
Create a Source for a thrift one server
- createThriftOneSource() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl
-
- createThriftTwoSource() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactory
-
Create a Source for a thrift two server
- createThriftTwoSource() - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceFactoryImpl
-
- createTopReference(byte[]) - Static method in class org.apache.hadoop.hbase.io.Reference
-
- createTreeSet() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- createUnescapdArgument(byte[], int, int) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Removes the single quote escaping a single quote - thus it returns an unescaped argument
- createUserForTesting(Configuration, String, String[]) - Static method in class org.apache.hadoop.hbase.security.User
-
Generates a new User
instance specifically for use in test code.
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- createValue() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- createVisibilityExpTags(String) - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
-
- createVisibilityExpTags(String) - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
-
Convert visibility expression into tags to be serialized.
- createVisibilityExpTags(String, boolean, boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- createVisibilityExpTags(String, boolean, boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Creates tags corresponding to given visibility expression.
- createVisibilityExpTags(String, boolean, boolean, Set<Integer>, VisibilityLabelOrdinalProvider) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- createVisibilityLabelFilter(Region, Authorizations) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- createWALWriter(FileSystem, Path) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Create a writer for the WAL.
- createWALWriter(FileSystem, Path, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
If you already have a WALFactory, you should favor the instance method.
- createWithParents(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node and all parent nodes required for it to exist.
- createWithParents(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Creates the specified node and all parent nodes required for it to exist.
- createWrapper(List<HTableInterface>, TableName, CoprocessorHost.Environment, ExecutorService) - Static method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- createWriter(FileSystem, Path, FSDataOutputStream, KeyValue.KVComparator, HFileContext) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.WriterFactory
-
- createWriter() - Method in interface org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.WriterFactory
-
- createWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest
-
- createWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequest
-
- createWriter() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
-
- createWriter(Configuration, FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
public because of FSHLog.
- createWriter(Path) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
- createWriterInstance(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
This method allows subclasses to inject different writers without having to
extend other methods like rollWriter().
- createWriterInTmp(long, Compression.Algorithm, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- createWriterInTmp(long, Compression.Algorithm, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- CREATION_TIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- CREATION_TIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- CREATOR_ALL_AND_WORLD_READABLE - Static variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- CREDENTIALS_LOCATION - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- CRLF - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- CRYPTO_ALTERNATE_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the alternate cipher algorithm for the cluster, a string
- CRYPTO_CIPHERPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto algorithm provider, a class name
- CRYPTO_KEY_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the algorithm used for creating jks key, a string
- CRYPTO_KEYPROVIDER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto key provider, a class name
- CRYPTO_KEYPROVIDER_PARAMETERS_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the crypto key provider parameters
- CRYPTO_MASTERKEY_ALTERNATE_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the alternate master key for the cluster, a string
- CRYPTO_MASTERKEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the master key for the cluster, a string
- CRYPTO_WAL_ALGORITHM_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the algorithm to use when encrypting the WAL, a string
- CRYPTO_WAL_KEY_NAME_CONF_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the name of the master WAL encryption key for the cluster, a string
- csm - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- ctx - Variable in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
- cur_worker_name - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- CurCall - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
This is set to Call object before Handler invokes an RPC and ybdie
after the call returns.
- current() - Method in interface org.apache.hadoop.hbase.CellScanner
-
- current() - Method in class org.apache.hadoop.hbase.client.Result
-
- current() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- current() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
CellScanner
- current - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
The current sub-scanner, i.e.
- CURRENT_COMPACTED_KVS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- CURRENT_VERSION - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- currentCellIndex - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- currentClientHasMinimumVersion(int, int) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
-
- currentCompactedKVs - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
the completed count of key values in currently running compaction
- CURRENTCOMPACTEDKVS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- currentComponent - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
-
- CurrentHourProvider - Class in org.apache.hadoop.hbase.regionserver.compactions
-
- currentPositionIsAfter(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
-
internal methods
- currentRegion - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- currentRowNode - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- currentTime() - Method in class org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
-
Returns the currentTime.
- currentTime() - Method in interface org.apache.hadoop.hbase.util.EnvironmentEdge
-
Returns the currentTime.
- currentTime() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
- currentTime() - Method in class org.apache.hadoop.hbase.util.IncrementingEnvironmentEdge
-
Returns the currentTime.
- currentTime() - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- currentTrailerSize() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationWALReaderManager
-
- currentWriteBufferSize - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- currKeyLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- currMemstoreTS - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- currMemstoreTSLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- currValueLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- CUSTOM_CALLER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
- CUSTOM_CONTROLLER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcControllerFactory
-
- CUSTOM_FILTERS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- CUSTOM_HEADER_PARAM - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- CUSTOM_METHODS_TO_IGNORE_PARAM - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- CUSTOM_RPC_CLIENT_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcClientFactory
-
- GENERAL_QUEUE_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- GENERAL_QUEUE_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- generalBloomFilter - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- GeneralBulkAssigner - Class in org.apache.hadoop.hbase.master
-
Run bulk assign.
- GeneralBulkAssigner(Server, Map<ServerName, List<HRegionInfo>>, AssignmentManager, boolean) - Constructor for class org.apache.hadoop.hbase.master.GeneralBulkAssigner
-
- generateDeadServersListToSend() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
Create the dead server to send.
- generateExceptionForChecksumFailureForTest(boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.ChecksumUtil
-
Mechanism to throw an exception in case of hbase checksum
failure.
- generateRandomSizeValue(byte[]...) - Method in class org.apache.hadoop.hbase.util.test.LoadTestKVGenerator
-
Generates a value for the given key index and column qualifier.
- generateTestKeyValues(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
Generate test data useful to test encoders.
- generateTestKeyValues(int, boolean) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
Generate test data useful to test encoders.
- generateToken(String) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- GENERIC_EXCEPTION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- Get - Class in org.apache.hadoop.hbase.client
-
Used to perform Get operations on a single row.
- Get(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Create a Get operation for the specified row.
- Get(Get) - Constructor for class org.apache.hadoop.hbase.client.Get
-
Copy-constructor
- get() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- get(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- get(Get) - Method in class org.apache.hadoop.hbase.client.HTable
-
Extracts certain cells from a given row.
- get(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Extracts certain cells from the given rows, in batch.
- get(Get) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- get(List<Get>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- get(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
Returns a list of all KeyValue objects with matching column family and qualifier.
- get - Variable in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
-
- get(Get) - Method in interface org.apache.hadoop.hbase.client.Table
-
Extracts certain cells from a given row.
- get(List<Get>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Extracts certain cells from the given rows, in batch.
- get() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
Currently unused.
- get(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- get(String, String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
Get the value of the name
.
- get(int) - Static method in enum org.apache.hadoop.hbase.executor.EventType
-
- get(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Create a new HFileSystem object, similar to FileSystem.get().
- get(Object) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- get() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
Get the data from the BytesWritable.
- get() - Method in class org.apache.hadoop.hbase.ipc.BlockingRpcCallback
-
- get(String) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- get() - Static method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
Get singleton instance.
- get(TKey) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureFairRunQueues
-
- get(RpcController, ClientProtos.GetRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface
-
- get(RpcController, ClientProtos.GetRequest, RpcCallback<ClientProtos.GetResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
-
rpc Get(.GetRequest) returns (.GetResponse);
- get(RpcController, ClientProtos.GetRequest, RpcCallback<ClientProtos.GetResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Interface
-
rpc Get(.GetRequest) returns (.GetResponse);
- get(RpcController, ClientProtos.GetRequest, RpcCallback<ClientProtos.GetResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Stub
-
- get(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- get(Get) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- get(Get, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- get(Object) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Retrieves the value associated with the specified key.
- get(Get) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Do a get based on the get parameter.
- get(Get, boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Do a get based on the get parameter.
- get(RpcController, ClientProtos.GetRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Get data from a table.
- get(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a GET request
- get(Get) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- get(List<Get>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ExistsResource
-
- get(int) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- get(int) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.MultiRowResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RegionsResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
- get(UriInfo, int, int) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.StorageClusterStatusResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.StorageClusterVersionResource
-
- get(UriInfo) - Method in class org.apache.hadoop.hbase.rest.TableScanResource
-
- get(ServletContext, UriInfo) - Method in class org.apache.hadoop.hbase.rest.VersionResource
-
Build a response for a version request.
- get(ZooKeeperWatcher, Configuration) - Static method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- get() - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- get(TableName) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
- get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.get_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.get_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get a single TCell for the specified table, row, and column at the
latest timestamp.
- get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Deprecated.
- get(ByteBuffer, ByteBuffer, byte[], byte[], Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Note: this internal interface is slightly different from public APIs in regard to handling
of the qualifier.
- get(ByteBuffer, TGet, AsyncMethodCallback<THBaseService.AsyncClient.get_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- get(ByteBuffer, TGet, AsyncMethodCallback<THBaseService.AsyncClient.get_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- get(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- get - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
the TGet to check for
- get - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
the TGet to fetch
- get(ByteBuffer, TGet) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Method for getting data from a row.
- get(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- get(String) - Method in class org.apache.hadoop.hbase.trace.HBaseHTraceConfiguration
-
- get(String, String) - Method in class org.apache.hadoop.hbase.trace.HBaseHTraceConfiguration
-
- get(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- get() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- get(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- get(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- get(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the byte at index
.
- get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Fill dst
with bytes from the range, starting from index
.
- get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Fill dst
with bytes from the range, starting from index
.
- get() - Method in class org.apache.hadoop.hbase.util.Counter
-
- get(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Get the current table descriptor for the given table, or null if none exists.
- get(Object) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- get() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- get() - Method in class org.apache.hadoop.hbase.util.PoolMap.ReusablePool
-
- get() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next byte from this range.
- get(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Fill dst
with bytes from the range, starting from position
.
- get(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Fill dst
with bytes from the range, starting from the current
position
.
- get(int, byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- get(int, byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- get(int, byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- get(int, byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- get(String) - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
-
- get(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Get a metric by name
- get75thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get95thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get98thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get999thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- get99thPercentile() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- GET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- GET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
- GET_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- getAbortNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Get the full znode path for the node used by the coordinator or member to trigger an abort
of the global barrier acquisition or execution in subprocedures.
- getAbortZNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAbortZnode() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAbsoluteFamilyOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getAbsoluteMetaOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
absolute getters
- getAbsoluteMvccVersionOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getAbsoluteQualifierOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getAbsoluteRowOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getAbsoluteTagsOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getAbsoluteTimestampOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getAbsoluteValueOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getACL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getACL() - Method in class org.apache.hadoop.hbase.client.Query
-
- getAcl(String, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getAcl is an idempotent operation.
- getAcquireBarrierNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Get the full znode path for the node used by the coordinator to trigger a global barrier
acquire on each subprocedure.
- getAcquiredBarrier() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAcquiredBarrierNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getAction() - Method in class org.apache.hadoop.hbase.client.Action
-
- getAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
repeated .Permission.Action action = 1;
- getAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
repeated .Permission.Action action = 1;
- getAction(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermissionOrBuilder
-
repeated .Permission.Action action = 1;
- getAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
repeated .Permission.Action action = 2;
- getAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
repeated .Permission.Action action = 2;
- getAction(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermissionOrBuilder
-
repeated .Permission.Action action = 2;
- getAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
repeated .Permission.Action action = 4;
- getAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
repeated .Permission.Action action = 4;
- getAction(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
-
repeated .Permission.Action action = 4;
- getAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- getAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
repeated .Action action = 3;
- getAction(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionOrBuilder
-
repeated .Action action = 3;
- getAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
required .FlushDescriptor.FlushAction action = 1;
- getAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
required .FlushDescriptor.FlushAction action = 1;
- getAction() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
required .FlushDescriptor.FlushAction action = 1;
- getAction() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getActionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- getActionBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- getActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
repeated .Permission.Action action = 1;
- getActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
repeated .Permission.Action action = 1;
- getActionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermissionOrBuilder
-
repeated .Permission.Action action = 1;
- getActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
repeated .Permission.Action action = 2;
- getActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
repeated .Permission.Action action = 2;
- getActionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermissionOrBuilder
-
repeated .Permission.Action action = 2;
- getActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
repeated .Permission.Action action = 4;
- getActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
repeated .Permission.Action action = 4;
- getActionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
-
repeated .Permission.Action action = 4;
- getActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- getActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
repeated .Action action = 3;
- getActionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionOrBuilder
-
repeated .Action action = 3;
- getActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
repeated .Permission.Action action = 1;
- getActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
repeated .Permission.Action action = 1;
- getActionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermissionOrBuilder
-
repeated .Permission.Action action = 1;
- getActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
repeated .Permission.Action action = 2;
- getActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
repeated .Permission.Action action = 2;
- getActionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermissionOrBuilder
-
repeated .Permission.Action action = 2;
- getActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
repeated .Permission.Action action = 4;
- getActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
repeated .Permission.Action action = 4;
- getActionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
-
repeated .Permission.Action action = 4;
- getActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- getActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
repeated .Action action = 3;
- getActionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionOrBuilder
-
repeated .Action action = 3;
- getActionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- getActionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
repeated .Action action = 3;
- getActionOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionOrBuilder
-
repeated .Action action = 3;
- getActionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- getActionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
repeated .Action action = 3;
- getActionOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionOrBuilder
-
repeated .Action action = 3;
- getActions() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- getActions() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- getActiveExecutorCount() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getActiveHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getActiveLogFiles() - Static method in class org.apache.hadoop.hbase.monitoring.LogMonitoring
-
- getActiveLogs() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- getActiveMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Gets the current active master, if available.
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getActiveRpcHandlerCount() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves the number of active handler.
- getActiveRpcHandlerCount() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getActiveTime() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the hbase master active time
- getActiveTime() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getActiveUser() - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- getAddress() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
-
- getAdmin(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Establishes a connection to the region server at the specified address.
- getAdmin() - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve an Admin implementation to administer an HBase cluster.
- getAdmin() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- getAdmin() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Retrieve an Admin implementation to administer an HBase cluster.
- getAdmin(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
internal method, do not use thru HConnection
- getAdmin(ServerName, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
You can pass master flag but nothing special is done.
- getAdmin() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to get the
Admin
.
- getAdmin() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Caller doesn't close the admin afterwards.
- getAgeAtEvictionSnapshot() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getAgeInCacheSnapshot() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
required uint64 ageOfLastAppliedOp = 1;
- getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
required uint64 ageOfLastAppliedOp = 1;
- getAgeOfLastAppliedOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSinkOrBuilder
-
required uint64 ageOfLastAppliedOp = 1;
- getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Get the Age of Last Applied Op
- getAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint64 ageOfLastShippedOp = 2;
- getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
required uint64 ageOfLastShippedOp = 2;
- getAgeOfLastShippedOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
-
required uint64 ageOfLastShippedOp = 2;
- getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get AgeOfLastShippedOp
- getAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getAggregateSource() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
Get the aggregate source to which this reports.
- getAggregateSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- getAlgorithm() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required string algorithm = 1;
- getAlgorithm() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
required string algorithm = 1;
- getAlgorithm() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
-
required string algorithm = 1;
- getAlgorithmBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required string algorithm = 1;
- getAlgorithmBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
required string algorithm = 1;
- getAlgorithmBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
-
required string algorithm = 1;
- getAliasPassword(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getAll() - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Get Map of all HTableDescriptors.
- getAll() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns a map from table name to table descriptor for all tables.
- getAllCached() - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- getAllExecutorStatuses() - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- getAllFilters() - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns all known filters
- getAllocator() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getAllowPartialResults() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getAllowPartialResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool allow_partial_results = 18;
- getAllowPartialResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bool allow_partial_results = 18;
- getAllowPartialResults() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bool allow_partial_results = 18;
- getAllPeerConfigs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
List the cluster replication configs of all remote slave clusters (whether they are
enabled/disabled or connected/disconnected).
- getAllPeerConfigs() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getAllPeerIds() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
List the peer ids of all remote slave clusters (whether they are enabled/disabled or
connected/disconnected).
- getAllPeerIds() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
List all registered peer clusters and set a watch on their znodes.
- getAllQueues() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Get a list of all queues for this region server.
- getAllQueues(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
-
Get a list of all queues for the specified region server.
- getAllQueues(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
-
- getAllQueues() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- getAllRegionLocations() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
- getAllRegionLocations() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getAllRegionLocations() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Retrieves all of the regions associated with this table.
- getAllSameTypeByte() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getAllTypes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getAlphabet(int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Returns one of the _SOMETHING_ALPHABET byte arrays depending on the options
specified.
- getAlterStatus(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the status of alter command - indicates how many regions have received the updated schema
Asynchronous operation.
- getAlterStatus(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the status of alter command - indicates how many regions have received the updated schema
Asynchronous operation.
- getAlterStatus(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the status of alter command - indicates how many regions have received
the updated schema Asynchronous operation.
- getAlterStatus(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the status of alter command - indicates how many regions have received
the updated schema Asynchronous operation.
- getAmmount() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- getAmount() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- getAndRemoveScopes() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- getAny() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- getAny() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- getAppend() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
The single append operation to apply
- getAppend() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
the TAppend to append
- getArchivedStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getArchivedStoreFileSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getArchivePath() - Method in class org.apache.hadoop.hbase.io.HFileLink
-
- getArchivePath(Configuration) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
- getArchiveZNode(Configuration, ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
- getArchivingEnabled(byte[]) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
Determine if archiving is enabled (but not necessarily fully propagated) for a table
- getArchivingEnabled(String) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
Determine if archiving is enabled (but not necessarily fully propagated) for a table
- getArrayOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getArrays() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- getAssignmentManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getAssignmentManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getAssignmentManager() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- getAssignmentManager() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getAssignmentManager__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getAssignmentMap() - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
-
- getAssignmentsByTable() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
This is an EXPENSIVE clone.
- getAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
optional bool assign_seq_num = 3;
- getAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
optional bool assign_seq_num = 3;
- getAssignSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
-
optional bool assign_seq_num = 3;
- getAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
optional bool assign_seq_num = 2;
- getAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
optional bool assign_seq_num = 2;
- getAssignSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
optional bool assign_seq_num = 2;
- getAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
optional int32 associated_cell_count = 3;
- getAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
optional int32 associated_cell_count = 3;
- getAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
-
optional int32 associated_cell_count = 3;
- getAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional int32 associated_cell_count = 8;
- getAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional int32 associated_cell_count = 8;
- getAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional int32 associated_cell_count = 8;
- getAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional int32 associated_cell_count = 2;
- getAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
optional int32 associated_cell_count = 2;
- getAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
optional int32 associated_cell_count = 2;
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.Factory
-
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.Factory
-
- getAsyncProcess() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- getAtomic() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
optional bool atomic = 2;
- getAtomic() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
optional bool atomic = 2;
- getAtomic() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionOrBuilder
-
optional bool atomic = 2;
- getAttemptTimes() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- getAttribute(String) - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Gets an attribute
- getAttribute(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAttribute(String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Get the value in the webapp context.
- getAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- getAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
repeated .NameBytesPair attribute = 3;
- getAttribute(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
repeated .NameBytesPair attribute = 3;
- getAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- getAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
repeated .NameBytesPair attribute = 5;
- getAttribute(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
repeated .NameBytesPair attribute = 5;
- getAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- getAttribute(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
repeated .NameBytesPair attribute = 2;
- getAttribute(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
repeated .NameBytesPair attribute = 2;
- getAttribute(String) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- getAttribute(String) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Return a table descriptor value as a string.
- getAttributeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- getAttributeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- getAttributeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- getAttributeBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- getAttributeBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- getAttributeBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- getAttributeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- getAttributeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
repeated .NameBytesPair attribute = 3;
- getAttributeCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
repeated .NameBytesPair attribute = 3;
- getAttributeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- getAttributeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
repeated .NameBytesPair attribute = 5;
- getAttributeCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
repeated .NameBytesPair attribute = 5;
- getAttributeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- getAttributeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
repeated .NameBytesPair attribute = 2;
- getAttributeCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
repeated .NameBytesPair attribute = 2;
- getAttributeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- getAttributeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
repeated .NameBytesPair attribute = 3;
- getAttributeList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
repeated .NameBytesPair attribute = 3;
- getAttributeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- getAttributeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
repeated .NameBytesPair attribute = 5;
- getAttributeList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
repeated .NameBytesPair attribute = 5;
- getAttributeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- getAttributeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
repeated .NameBytesPair attribute = 2;
- getAttributeList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
repeated .NameBytesPair attribute = 2;
- getAttributeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- getAttributeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
repeated .NameBytesPair attribute = 3;
- getAttributeOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
repeated .NameBytesPair attribute = 3;
- getAttributeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- getAttributeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
repeated .NameBytesPair attribute = 5;
- getAttributeOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
repeated .NameBytesPair attribute = 5;
- getAttributeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- getAttributeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
repeated .NameBytesPair attribute = 2;
- getAttributeOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
repeated .NameBytesPair attribute = 2;
- getAttributeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- getAttributeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
repeated .NameBytesPair attribute = 3;
- getAttributeOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
repeated .NameBytesPair attribute = 3;
- getAttributeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- getAttributeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
repeated .NameBytesPair attribute = 5;
- getAttributeOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
repeated .NameBytesPair attribute = 5;
- getAttributeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- getAttributeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
repeated .NameBytesPair attribute = 2;
- getAttributeOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
repeated .NameBytesPair attribute = 2;
- getAttributes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
repeated .BytesBytesPair attributes = 2;
- getAttributes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
-
repeated .BytesBytesPair attributes = 2;
- getAttributes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .BytesBytesPair attributes = 2;
- getAttributes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .BytesBytesPair attributes = 2;
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
Mutation attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Delete attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Delete attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Delete attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Delete attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Get attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Mutation attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
Mutation attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Mutation attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Mutation attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Scan attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Scan attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Scan attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Scan attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Scan attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Scan attributes
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getAttributes() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getAttributesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
repeated .BytesBytesPair attributes = 2;
- getAttributesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .BytesBytesPair attributes = 2;
- getAttributesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .BytesBytesPair attributes = 2;
- getAttributeSize() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAttributesKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getAttributesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
repeated .BytesBytesPair attributes = 2;
- getAttributesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .BytesBytesPair attributes = 2;
- getAttributesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesMap() - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Gets all attributes
- getAttributesMap() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- getAttributesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
repeated .BytesBytesPair attributes = 2;
- getAttributesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .BytesBytesPair attributes = 2;
- getAttributesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
repeated .BytesBytesPair attributes = 2;
- getAttributesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .BytesBytesPair attributes = 2;
- getAttributesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .BytesBytesPair attributes = 2;
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getAttributesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrs(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrs(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrs(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAttrsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- getAuth(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
repeated bytes auth = 2;
- getAuth(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
repeated bytes auth = 2;
- getAuth(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponseOrBuilder
-
repeated bytes auth = 2;
- getAuth(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
repeated bytes auth = 2;
- getAuth(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
repeated bytes auth = 2;
- getAuth(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequestOrBuilder
-
repeated bytes auth = 2;
- getAuth(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
repeated uint32 auth = 2;
- getAuth(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
repeated uint32 auth = 2;
- getAuth(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizationsOrBuilder
-
repeated uint32 auth = 2;
- getAuthChore(Configuration) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Checks if security is enabled and if so, launches chore for refreshing kerberos ticket.
- getAuthCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
repeated bytes auth = 2;
- getAuthCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
repeated bytes auth = 2;
- getAuthCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponseOrBuilder
-
repeated bytes auth = 2;
- getAuthCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
repeated bytes auth = 2;
- getAuthCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
repeated bytes auth = 2;
- getAuthCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequestOrBuilder
-
repeated bytes auth = 2;
- getAuthCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
repeated uint32 auth = 2;
- getAuthCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
repeated uint32 auth = 2;
- getAuthCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizationsOrBuilder
-
repeated uint32 auth = 2;
- getAuthenticationToken(RpcController, AuthenticationProtos.GetAuthenticationTokenRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.BlockingInterface
-
- getAuthenticationToken(RpcController, AuthenticationProtos.GetAuthenticationTokenRequest, RpcCallback<AuthenticationProtos.GetAuthenticationTokenResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
-
rpc GetAuthenticationToken(.GetAuthenticationTokenRequest) returns (.GetAuthenticationTokenResponse);
- getAuthenticationToken(RpcController, AuthenticationProtos.GetAuthenticationTokenRequest, RpcCallback<AuthenticationProtos.GetAuthenticationTokenResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.Interface
-
rpc GetAuthenticationToken(.GetAuthenticationTokenRequest) returns (.GetAuthenticationTokenResponse);
- getAuthenticationToken(RpcController, AuthenticationProtos.GetAuthenticationTokenRequest, RpcCallback<AuthenticationProtos.GetAuthenticationTokenResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.Stub
-
- getAuthenticationToken(RpcController, AuthenticationProtos.GetAuthenticationTokenRequest, RpcCallback<AuthenticationProtos.GetAuthenticationTokenResponse>) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- getAuthList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
repeated bytes auth = 2;
- getAuthList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
repeated bytes auth = 2;
- getAuthList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponseOrBuilder
-
repeated bytes auth = 2;
- getAuthList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
repeated bytes auth = 2;
- getAuthList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
repeated bytes auth = 2;
- getAuthList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequestOrBuilder
-
repeated bytes auth = 2;
- getAuthList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
repeated uint32 auth = 2;
- getAuthList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
repeated uint32 auth = 2;
- getAuthList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizationsOrBuilder
-
repeated uint32 auth = 2;
- getAuthManager() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getAuthMethod() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
optional string auth_method = 2;
- getAuthMethod() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
optional string auth_method = 2;
- getAuthMethod() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponseOrBuilder
-
optional string auth_method = 2;
- getAuthMethodBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
optional string auth_method = 2;
- getAuthMethodBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
optional string auth_method = 2;
- getAuthMethodBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponseOrBuilder
-
optional string auth_method = 2;
- getAuthorizations() - Method in class org.apache.hadoop.hbase.client.Query
-
- getAuthorizations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getAuthorizations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getAuths(RpcController, VisibilityLabelsProtos.GetAuthsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.BlockingInterface
-
- getAuths(RpcController, VisibilityLabelsProtos.GetAuthsRequest, RpcCallback<VisibilityLabelsProtos.GetAuthsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService
-
rpc getAuths(.GetAuthsRequest) returns (.GetAuthsResponse);
- getAuths(RpcController, VisibilityLabelsProtos.GetAuthsRequest, RpcCallback<VisibilityLabelsProtos.GetAuthsResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.Interface
-
rpc getAuths(.GetAuthsRequest) returns (.GetAuthsResponse);
- getAuths(RpcController, VisibilityLabelsProtos.GetAuthsRequest, RpcCallback<VisibilityLabelsProtos.GetAuthsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.Stub
-
- getAuths(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
Deprecated.
- getAuths(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
- getAuths(RpcController, VisibilityLabelsProtos.GetAuthsRequest, RpcCallback<VisibilityLabelsProtos.GetAuthsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- getAuths(byte[], boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
- getAvailable() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- getAvailablePath(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
-
- getAverageLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Compute the average load across all region servers.
- getAverageLoad() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get Average Load
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Compute the average load across all region servers.
- getAverageLoad() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Compute the average load across all region servers.
- getAverageLoad() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
optional double averageLoad = 5;
- getAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
optional double averageLoad = 5;
- getAverageLoad() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
optional double averageLoad = 5;
- getAvg(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives a Pair with first object as Sum and second object as row count,
computed for a given combination of column qualifier and column family in
the given row range as defined in the Scan object.
- getAvg(RpcController, AggregateProtos.AggregateRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
-
- getAvg(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
rpc GetAvg(.AggregateRequest) returns (.AggregateResponse);
- getAvg(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
-
rpc GetAvg(.AggregateRequest) returns (.AggregateResponse);
- getAvg(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
-
- getAvgOperationSize(OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- getAvgOperationSize(OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- getAvgOperationSize(OperationQuota.OperationType) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
- getAvgOperationSize(OperationQuota.OperationType) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
- getAvgOperationSize(OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- getAvgSize() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
-
- getBackingFs() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Returns the underlying filesystem
- getBackoffPolicy() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- getBackoffPolicy() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
-
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicyFactory.NoBackoffPolicy
-
- getBackoffTime(ServerName, byte[], ServerStatistics) - Method in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- getBackoffTime(RetryCounter.RetryConfig, int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.BackoffPolicy
-
- getBackoffTime(RetryCounter.RetryConfig, int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicy
-
- getBackoffTime(RetryCounter.RetryConfig, int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.ExponentialBackoffPolicyWithLimit
-
- getBackReferenceFileName(Path) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
Get the referenced file name from the reference link directory path.
- getBackReferencesDir(Path, String) - Static method in class org.apache.hadoop.hbase.io.FileLink
-
Get the directory to store the link back references
- getBackupMasterInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the info port of the backup master if it is available.
- getBackupMasters() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getBackupMasters(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- getBackupMasters(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .ServerName backup_masters = 8;
- getBackupMasters(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .ServerName backup_masters = 8;
- getBackupMastersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- getBackupMastersBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- getBackupMastersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- getBackupMastersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .ServerName backup_masters = 8;
- getBackupMastersCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .ServerName backup_masters = 8;
- getBackupMastersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- getBackupMastersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .ServerName backup_masters = 8;
- getBackupMastersList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .ServerName backup_masters = 8;
- getBackupMastersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- getBackupMastersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .ServerName backup_masters = 8;
- getBackupMastersOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .ServerName backup_masters = 8;
- getBackupMastersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- getBackupMastersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .ServerName backup_masters = 8;
- getBackupMastersOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .ServerName backup_masters = 8;
- getBackupMastersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getBackupZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getBadLineCount() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- getBalancer(int) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- getBalancer() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- getBalancerOn() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional bool balancer_on = 9;
- getBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
optional bool balancer_on = 9;
- getBalancerOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
optional bool balancer_on = 9;
- getBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
-
optional bool balancer_on = 1;
- getBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
optional bool balancer_on = 1;
- getBalancerOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerStateOrBuilder
-
optional bool balancer_on = 1;
- getBalancerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
-
required bool balancer_ran = 1;
- getBalancerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
required bool balancer_ran = 1;
- getBalancerRan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponseOrBuilder
-
required bool balancer_ran = 1;
- getBaseOffset() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- getBaseStagingDir(Configuration) - Static method in class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
-
- getBaseZnode() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getBaseZNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- getBatch() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getBatch() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getBatch() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int32 batch = 4;
- getBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional int32 batch = 4;
- getBatch() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional int32 batch = 4;
- getBatchSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 batch_size = 9;
- getBatchSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional uint32 batch_size = 9;
- getBatchSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional uint32 batch_size = 9;
- getBatchSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getBatchSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getBcn() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- getBcn() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getBcn__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getBcv() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- getBcv() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getBcv__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getBestLocations(Configuration, HDFSBlocksDistribution) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
This computes the locations to be passed from the InputSplit.
- getBigdecimalMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
-
required bytes bigdecimal_msg = 1;
- getBigdecimalMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
required bytes bigdecimal_msg = 1;
- getBigdecimalMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsgOrBuilder
-
required bytes bigdecimal_msg = 1;
- getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
- getBinary(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- getBitwiseOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
required .BitComparator.BitwiseOp bitwise_op = 2;
- getBitwiseOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
required .BitComparator.BitwiseOp bitwise_op = 2;
- getBitwiseOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparatorOrBuilder
-
required .BitComparator.BitwiseOp bitwise_op = 2;
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Fetch block from cache.
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Get the buffer of the block with the specified key.
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.InclusiveCombinedBlockCache
-
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the buffer of the block with the specified name.
- getBlock(BlockCacheKey, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getBlockCache() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns the block cache.
- getBlockCacheCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of items in the block cache.
- getBlockCacheEvictedCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of items evicted from the block cache.
- getBlockCacheFreeSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size (in bytes) of the block cache that is free.
- getBlockCacheHeapPercent(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
-
Retrieve configured size for on heap block cache as percentage of total heap.
- getBlockCacheHitCachingPercent() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the percent of requests with the block cache turned on that hit the block cache.
- getBlockCacheHitCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the count of hits to the block cache
- getBlockCacheHitPercent() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the percent of all requests that hit the block cache.
- getBlockCacheMissCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the count of misses to the block cache.
- getBlockCaches() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getBlockCaches() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getBlockCacheSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- getBlockCacheSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total size (in bytes) of the block cache.
- getBlockCount() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the number of blocks currently cached in the block cache.
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getBlockDecodingContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
- getBlockedFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getBlockedRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getBlockedRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getBlockedRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getBlockForCaching(CacheConfig) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Creates a new HFileBlock.
- getBlockingFileCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getBlockingFileCount() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
The number of files required before flushes for this store will be blocked.
- getBlockingService() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
-
- getBlockLocalityIndex(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
return the locality index of a given host
- getBlockMeta() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- getBlockMeta() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
get/set
- getBlockPriority() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getBlocksize() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getBlockSize() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- getBlockSize() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Get the cipher's internal block size
- getBlockSize() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the cipher's internal block size
- getBlocksize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getBlockType() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.BlockWritable
-
The type of block this data should use.
- getBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getBloomBlockSize(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- getBloomFilterNbHashes() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getBloomFilterType() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getBloomFilterVectorSize() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getBnlIndicator(boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getBoolean(String, boolean) - Method in class org.apache.hadoop.hbase.trace.HBaseHTraceConfiguration
-
- getBoundedCachedThreadPool(int, long, TimeUnit, ThreadFactory) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Create a new CachedThreadPool with a bounded number as the maximum
thread size in the pool.
- getBranchNubLeafIndicator() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getBuckets() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getBuffer() - Method in class org.apache.hadoop.hbase.io.BoundedByteBufferPool
-
- getBuffer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer.BufferGrabbingByteArrayOutputStream
-
- getBuffer() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- getBuffer() - Method in class org.apache.hadoop.hbase.KeyValue
-
Deprecated.
Since 0.98.0. Use Cell Interface instead. Do not presume single backing buffer.
- getBuffer() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- getBuffer() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
- getBuffer() - Method in class org.apache.hadoop.hbase.Tag
-
- getBufferedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getBufferedMutator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
- getBufferedMutator(BufferedMutatorParams) - Method in interface org.apache.hadoop.hbase.client.Connection
-
- getBufferOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getBufferReadOnly() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the buffer this block stores internally.
- getBufferReadOnlyWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the buffer of this block, including header data.
- getBufferWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns a buffer that does not include the header or checksum.
- getBuilder(WALCellCodec.ByteStringCompressor) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getBulkLoadDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
Deserialized and returns a BulkLoadDescriptor from the passed in Cell
- getBulkloadSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required int64 bulkload_seq_num = 4;
- getBulkloadSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
required int64 bulkload_seq_num = 4;
- getBulkloadSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
-
required int64 bulkload_seq_num = 4;
- getBulkLoadTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Return the timestamp at which this bulk load file was generated.
- getBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
required string bulk_token = 1;
- getBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
required string bulk_token = 1;
- getBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequestOrBuilder
-
required string bulk_token = 1;
- getBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
required string bulk_token = 1;
- getBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
required string bulk_token = 1;
- getBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponseOrBuilder
-
required string bulk_token = 1;
- getBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required string bulk_token = 4;
- getBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
required string bulk_token = 4;
- getBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
required string bulk_token = 4;
- getBulkTokenBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
required string bulk_token = 1;
- getBulkTokenBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
required string bulk_token = 1;
- getBulkTokenBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequestOrBuilder
-
required string bulk_token = 1;
- getBulkTokenBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
required string bulk_token = 1;
- getBulkTokenBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
required string bulk_token = 1;
- getBulkTokenBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponseOrBuilder
-
required string bulk_token = 1;
- getBulkTokenBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required string bulk_token = 4;
- getBulkTokenBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
required string bulk_token = 4;
- getBulkTokenBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
required string bulk_token = 4;
- getByNamespace(String) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Get Map of all NamespaceDescriptors for a given namespace.
- getByNamespace(String) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- getBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional bool bypass_globals = 6;
- getBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional bool bypass_globals = 6;
- getBypassGlobals() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional bool bypass_globals = 6;
- getBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
optional bool bypass_globals = 1 [default = false];
- getBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
optional bool bypass_globals = 1 [default = false];
- getBypassGlobals() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotasOrBuilder
-
optional bool bypass_globals = 1 [default = false];
- getByteArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
- getByteBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
This flips the underlying BB so be sure to use it _last_!
- getBytes() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getBytes() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The underlying byte[].
- getBytes(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Returns a new byte array, copied from the given buf
,
from the position (inclusive) to the limit (exclusive).
- getBytes() - Method in class org.apache.hadoop.hbase.util.HashedBytes
-
- getBytes(int, long) - Static method in class org.apache.hadoop.hbase.util.vint.UFIntTool
-
- getBytes(int) - Static method in class org.apache.hadoop.hbase.util.vint.UVIntTool
-
- getBytes(long) - Static method in class org.apache.hadoop.hbase.util.vint.UVLongTool
-
- getBytes(Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
- getBytes(Writable...) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Put a bunch of Writables as bytes all into the one byte array.
- getByteSize() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
- getByteSize() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getByteSize() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- getBytesPerChecksum() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getBytesPerChecksum(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns the configured bytesPerChecksum value.
- getBytesPerDelta() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
- getBytesPerIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
- getBytesPerSec() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
Getter for the read-rate from this stream, since creation.
- getByteStream() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getByteStringCompressor() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getByteStringUncompressor() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Get
-
Get whether blocks should be cached for this Get.
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get whether blocks should be cached for this Scan.
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional bool cache_blocks = 7 [default = true];
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional bool cache_blocks = 7 [default = true];
- getCacheBlocks() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional bool cache_blocks = 7 [default = true];
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool cache_blocks = 8 [default = true];
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bool cache_blocks = 8 [default = true];
- getCacheBlocks() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bool cache_blocks = 8 [default = true];
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional bool cacheBlocks = 11;
- getCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional bool cacheBlocks = 11;
- getCacheBlocks() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional bool cacheBlocks = 11;
- getCacheConfig() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCacheConfig() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCacheConfig() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Used for tests.
- getCacheConfig() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
-
- getCacheConfig() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- getCachedBlockStatsByFile() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getCachedLocation(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Search the cache for a location that fits our table and row key.
- getCachedTime() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getCachedTime() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- getCacheKey() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- getCacheOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- getCacheOnWrite() - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
- getCacheOnWrite() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- getCacheSize() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getCaching() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getCaching() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getCaching() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Get the number of rows that will be fetched on next
- getCaching() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 caching = 17;
- getCaching() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional uint32 caching = 17;
- getCaching() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional uint32 caching = 17;
- getCaching() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int32 caching = 9;
- getCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional int32 caching = 9;
- getCaching() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional int32 caching = 9;
- getCaching() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getCaching() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getCall() - Method in class org.apache.hadoop.hbase.ipc.CallRunner
-
- getCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .CoprocessorServiceCall call = 2;
- getCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
required .CoprocessorServiceCall call = 2;
- getCall() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
-
required .CoprocessorServiceCall call = 2;
- getCallable(ClusterConnection, TableName, Scan, ScanMetrics, byte[], int, RpcControllerFactory, ExecutorService, int, int, int, Configuration, RpcRetryingCaller<Result[]>) - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner.SmallScannerCallableFactory
-
- getCallBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .CoprocessorServiceCall call = 2;
- getCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional uint32 call_id = 1;
- getCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional uint32 call_id = 1;
- getCallId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional uint32 call_id = 1;
- getCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional uint32 call_id = 1;
- getCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
optional uint32 call_id = 1;
- getCallId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
-
optional uint32 call_id = 1;
- getCallOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .CoprocessorServiceCall call = 2;
- getCallOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
required .CoprocessorServiceCall call = 2;
- getCallOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
-
required .CoprocessorServiceCall call = 2;
- getCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
-
- getCandidateFilesForRowKeyBefore(KeyValue) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets initial, full list of candidate store files to check for row-key-before.
- getCandidateFilesForRowKeyBefore(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getCatalogJanitorEnabled__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getCategory() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- getCause(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getCauses() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getCell(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- getCell(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
repeated .Cell cell = 1;
- getCell(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
repeated .Cell cell = 1;
- getCell() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- getCellBlockCodecClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string cell_block_codec_class = 3;
- getCellBlockCodecClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional string cell_block_codec_class = 3;
- getCellBlockCodecClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional string cell_block_codec_class = 3;
- getCellBlockCodecClassBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string cell_block_codec_class = 3;
- getCellBlockCodecClassBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional string cell_block_codec_class = 3;
- getCellBlockCodecClassBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional string cell_block_codec_class = 3;
- getCellBlockCompressorClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string cell_block_compressor_class = 4;
- getCellBlockCompressorClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional string cell_block_compressor_class = 4;
- getCellBlockCompressorClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional string cell_block_compressor_class = 4;
- getCellBlockCompressorClassBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string cell_block_compressor_class = 4;
- getCellBlockCompressorClassBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional string cell_block_compressor_class = 4;
- getCellBlockCompressorClassBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional string cell_block_compressor_class = 4;
- getCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 5;
- getCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional .CellBlockMeta cell_block_meta = 5;
- getCellBlockMeta() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional .CellBlockMeta cell_block_meta = 5;
- getCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 3;
- getCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
optional .CellBlockMeta cell_block_meta = 3;
- getCellBlockMeta() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
-
optional .CellBlockMeta cell_block_meta = 3;
- getCellBlockMetaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 5;
- getCellBlockMetaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 3;
- getCellBlockMetaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 5;
- getCellBlockMetaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional .CellBlockMeta cell_block_meta = 5;
- getCellBlockMetaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional .CellBlockMeta cell_block_meta = 5;
- getCellBlockMetaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 3;
- getCellBlockMetaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
optional .CellBlockMeta cell_block_meta = 3;
- getCellBlockMetaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
-
optional .CellBlockMeta cell_block_meta = 3;
- getCellBufSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getCellBufSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
-
- getCellBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- getCellBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- getCellCodecClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional string cell_codec_cls_name = 5;
- getCellCodecClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
optional string cell_codec_cls_name = 5;
- getCellCodecClsName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
-
optional string cell_codec_cls_name = 5;
- getCellCodecClsNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional string cell_codec_cls_name = 5;
- getCellCodecClsNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
optional string cell_codec_cls_name = 5;
- getCellCodecClsNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
-
optional string cell_codec_cls_name = 5;
- getCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- getCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
repeated .Cell cell = 1;
- getCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
repeated .Cell cell = 1;
- getCellKeyAsString(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getCellKeySerializedAsKeyValueKey(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
This method exists just to encapsulate how we serialize keys.
- getCellList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- getCellList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
repeated .Cell cell = 1;
- getCellList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
repeated .Cell cell = 1;
- getCellOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- getCellOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
repeated .Cell cell = 1;
- getCellOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
repeated .Cell cell = 1;
- getCellOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- getCellOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
repeated .Cell cell = 1;
- getCellOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
repeated .Cell cell = 1;
- getCellPermissionsForUser(User, Cell) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- getCells() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- getCells() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- getCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getCellsPerResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated uint32 cells_per_result = 1;
- getCellsPerResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
repeated uint32 cells_per_result = 1;
- getCellsPerResult(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
repeated uint32 cells_per_result = 1;
- getCellsPerResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated uint32 cells_per_result = 1;
- getCellsPerResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
repeated uint32 cells_per_result = 1;
- getCellsPerResultCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
repeated uint32 cells_per_result = 1;
- getCellsPerResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated uint32 cells_per_result = 1;
- getCellsPerResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
repeated uint32 cells_per_result = 1;
- getCellsPerResultList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
repeated uint32 cells_per_result = 1;
- getCellTTLColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getCellType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional .CellType cell_type = 5;
- getCellType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional .CellType cell_type = 5;
- getCellType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional .CellType cell_type = 5;
- getCellValueFromProto(HBaseProtos.BigDecimalMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getCellValueFromProto(HBaseProtos.DoubleMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getCellValueFromProto(HBaseProtos.LongMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getCellValueFromProto(Q) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the PB message corresponding to the cell type
- getCellVisibility() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- getCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getCellVisibility() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getCellVisibilityColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getChance() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- getChance() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
-
required float chance = 1;
- getChance() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
required float chance = 1;
- getChance() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilterOrBuilder
-
required float chance = 1;
- getChannel() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService.Stub
-
- getChannel() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.Stub
-
- getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Stub
-
- getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
-
- getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
-
- getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService.Stub
-
- getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Stub
-
- getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationService.Stub
-
- getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.Stub
-
- getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService.Stub
-
- getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Stub
-
- getChannel() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.Stub
-
- getCharset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required string charset = 3;
- getCharset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
required string charset = 3;
- getCharset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
-
required string charset = 3;
- getCharsetBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required string charset = 3;
- getCharsetBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
required string charset = 3;
- getCharsetBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
-
required string charset = 3;
- getCheckAndMutateChecksFailed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCheckAndMutateChecksFailed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of CAS operations that failed.
- getCheckAndMutateChecksFailed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getCheckAndMutateChecksPassed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCheckAndMutateChecksPassed() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of CAS operations that passed.
- getCheckAndMutateChecksPassed() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getChecksumFailuresCount() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Number of checksum verification failures.
- getChecksumObject() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
-
returns a object that can be used to generate/validate checksums
- getChecksumType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getChecksumType(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns the configured checksum algorithm.
- getChildDataAndWatchForNewChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- getChildExps() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- getChildren() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getChildren(String, Watcher) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getChildren is an idempotent operation.
- getChildren(String, boolean) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getChildren is an idempotent operation.
- getChildSequenceId(String) - Static method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.ZNodeComparator
-
Parses sequenceId from the znode name.
- getChoreService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getChoreService() - Method in interface org.apache.hadoop.hbase.Server
-
- getCipher(String) - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Get an Cipher
- getCipher() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getCipher(String) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getCipher(Configuration, String) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get an cipher given a name
- getCipherProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- getClassByName(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- getClassLoader() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getClassLoader() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getClassLoader(Path, ClassLoader, String, Configuration) - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
Get a CoprocessorClassLoader for a coprocessor jar path from cache.
- getClassLoadingLock(String) - Method in class org.apache.hadoop.hbase.util.ClassLoaderBase
-
Returns the lock object for class loading operations.
- getClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional string class_name = 1;
- getClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
optional string class_name = 1;
- getClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
optional string class_name = 1;
- getClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required string class_name = 1;
- getClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
required string class_name = 1;
- getClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
required string class_name = 1;
- getClassNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional string class_name = 1;
- getClassNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
optional string class_name = 1;
- getClassNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
optional string class_name = 1;
- getClassNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required string class_name = 1;
- getClassNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
required string class_name = 1;
- getClassNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
required string class_name = 1;
- getClient(ServerName) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Establishes a connection to the region server at the specified address, and returns
a region client protocol.
- getClient(ServerName) - Method in class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
- getClient(ServerName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
internal method, do not use thru HConnection
- getClient() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getClient() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
If an RPC call is currently running, produces a String representation of
the connection from which it was received.
- getClient(TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client.Factory
-
- getClient(TProtocol, TProtocol) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client.Factory
-
- getClient(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client.Factory
-
- getClient(TProtocol, TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client.Factory
-
- getClientAckTime() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getClientHandlesHeartbeats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool client_handles_heartbeats = 8;
- getClientHandlesHeartbeats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional bool client_handles_heartbeats = 8;
- getClientHandlesHeartbeats() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional bool client_handles_heartbeats = 8;
- getClientHandlesPartials() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool client_handles_partials = 7;
- getClientHandlesPartials() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional bool client_handles_partials = 7;
- getClientHandlesPartials() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional bool client_handles_partials = 7;
- getClientPort() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getClientPortList() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Get the list of client ports.
- getClientVersionInfo() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
- getClientVersionInfo() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getCloseCheckInterval() - Static method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getClosed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
-
required bool closed = 1;
- getClosed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
required bool closed = 1;
- getClosed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponseOrBuilder
-
required bool closed = 1;
- getCloseRegionCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
Method to retrieve coordination for closing region operations.
- getCloseRegionCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getCloseScanner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool close_scanner = 5;
- getCloseScanner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional bool close_scanner = 5;
- getCloseScanner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional bool close_scanner = 5;
- getClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional bool closest_row_before = 11 [default = false];
- getClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional bool closest_row_before = 11 [default = false];
- getClosestRowBefore() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional bool closest_row_before = 11 [default = false];
- getClosestRowBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getClosestRowBefore(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return all the data for the row that matches row exactly,
or the one that immediately preceeds it, at or immediately before
ts.
- getCluster() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
- getClusterId() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getClusterId() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getClusterId() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the Cluster ID
- getClusterId() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
required string cluster_id = 1;
- getClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
required string cluster_id = 1;
- getClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterIdOrBuilder
-
required string cluster_id = 1;
- getClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ClusterId cluster_id = 5;
- getClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
optional .ClusterId cluster_id = 5;
- getClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
optional .ClusterId cluster_id = 5;
- getClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
Deprecated.
- getClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
Deprecated.
- getClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
Deprecated.
- getClusterId() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getClusterId() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the Cluster ID
- getClusterId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getClusterId(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the value of the unique cluster ID stored for this HBase instance.
- getClusterIdBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ClusterId cluster_id = 5;
- getClusterIdBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
Deprecated.
- getClusterIdBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
required string cluster_id = 1;
- getClusterIdBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
required string cluster_id = 1;
- getClusterIdBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterIdOrBuilder
-
required string cluster_id = 1;
- getClusterIdOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ClusterId cluster_id = 5;
- getClusterIdOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
optional .ClusterId cluster_id = 5;
- getClusterIdOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
optional .ClusterId cluster_id = 5;
- getClusterIdOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
Deprecated.
- getClusterIdOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
Deprecated.
- getClusterIdOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
Deprecated.
- getClusterIds() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getClusterIds(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- getClusterIds(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
repeated .UUID cluster_ids = 8;
- getClusterIds(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
repeated .UUID cluster_ids = 8;
- getClusterIds() - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- getClusterIds() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
- getClusterIds() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getClusterIdsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- getClusterIdsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- getClusterIdsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- getClusterIdsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
repeated .UUID cluster_ids = 8;
- getClusterIdsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
repeated .UUID cluster_ids = 8;
- getClusterIdsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- getClusterIdsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
repeated .UUID cluster_ids = 8;
- getClusterIdsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
repeated .UUID cluster_ids = 8;
- getClusterIdsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- getClusterIdsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
repeated .UUID cluster_ids = 8;
- getClusterIdsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
repeated .UUID cluster_ids = 8;
- getClusterIdsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- getClusterIdsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
repeated .UUID cluster_ids = 8;
- getClusterIdsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
repeated .UUID cluster_ids = 8;
- getClusterkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
required string clusterkey = 1;
- getClusterkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
required string clusterkey = 1;
- getClusterkey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
required string clusterkey = 1;
- getClusterKey() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getClusterkeyBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
required string clusterkey = 1;
- getClusterkeyBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
required string clusterkey = 1;
- getClusterkeyBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
required string clusterkey = 1;
- getClusterStatus() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getClusterStatus() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getClusterStatus() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getClusterStatus(RpcController, MasterProtos.GetClusterStatusRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getClusterStatus() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
required .ClusterStatus cluster_status = 1;
- getClusterStatus() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
required .ClusterStatus cluster_status = 1;
- getClusterStatus() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponseOrBuilder
-
required .ClusterStatus cluster_status = 1;
- getClusterStatus(RpcController, MasterProtos.GetClusterStatusRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- getClusterStatus(RpcController, MasterProtos.GetClusterStatusRequest, RpcCallback<MasterProtos.GetClusterStatusResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc GetClusterStatus(.GetClusterStatusRequest) returns (.GetClusterStatusResponse);
- getClusterStatus(RpcController, MasterProtos.GetClusterStatusRequest, RpcCallback<MasterProtos.GetClusterStatusResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc GetClusterStatus(.GetClusterStatusRequest) returns (.GetClusterStatusResponse);
- getClusterStatus(RpcController, MasterProtos.GetClusterStatusRequest, RpcCallback<MasterProtos.GetClusterStatusResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- getClusterStatus() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- getClusterStatusBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
required .ClusterStatus cluster_status = 1;
- getClusterStatusOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
required .ClusterStatus cluster_status = 1;
- getClusterStatusOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
required .ClusterStatus cluster_status = 1;
- getClusterStatusOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponseOrBuilder
-
required .ClusterStatus cluster_status = 1;
- getClusterStatusResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- getClusterVersion() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- getClusterVersionResource() - Method in class org.apache.hadoop.hbase.rest.VersionResource
-
Dispatch to StorageClusterVersionResource
- getCode() - Method in enum org.apache.hadoop.hbase.executor.EventType
-
- getCode() - Method in enum org.apache.hadoop.hbase.KeyValue.Type
-
- getCode() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getCode() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getCode() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
-
- getCodec(Configuration, String, CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getCodec(Configuration, CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- getCodec(Configuration, Encryptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- getCodec(Configuration, Decryptor) - Static method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- getCodecClsName() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
- getColumn(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- getColumn(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
repeated .Column column = 2;
- getColumn(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
repeated .Column column = 2;
- getColumn(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- getColumn(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
repeated .Column column = 1;
- getColumn(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
repeated .Column column = 1;
- getColumn() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- getColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional bytes column = 2;
- getColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
optional bytes column = 2;
- getColumn() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
optional bytes column = 2;
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
name of column
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
column name
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
name of column whose value is to be deleted
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
name of column whose value is to be deleted
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
column name
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
column name
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
column name
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- getColumn() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- getColumnBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- getColumnBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- getColumnBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- getColumnBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- getColumnCells(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Return the Cells for the specific column.
- getColumnCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- getColumnCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
repeated .Column column = 2;
- getColumnCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
repeated .Column column = 2;
- getColumnCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- getColumnCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
repeated .Column column = 1;
- getColumnCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
repeated .Column column = 1;
- getColumnDescriptors(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getColumnDescriptors_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getColumnDescriptors(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getColumnDescriptors_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getColumnDescriptors(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getColumnDescriptors(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
List all the column families assoicated with a table.
- getColumnDescriptors(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getColumnFamilies(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamilies(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamilies(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamilies() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequestOrBuilder
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamilies() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequestOrBuilder
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamilies() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
list of column family descriptors
- getColumnFamiliesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamiliesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamiliesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- getColumnFamiliesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamiliesOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamiliesOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequestOrBuilder
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamiliesOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamiliesOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamiliesOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequestOrBuilder
-
required .ColumnFamilySchema column_families = 2;
- getColumnFamiliesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .ColumnFamilySchema column_families = 3;
- getColumnFamiliesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- getColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
optional bytes column_family = 2;
- getColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
optional bytes column_family = 2;
- getColumnFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
-
optional bytes column_family = 2;
- getColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bytes column_family = 1;
- getColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
optional bytes column_family = 1;
- getColumnFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
optional bytes column_family = 1;
- getColumnFamily(int) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Retrieve the column family at the given index from the table descriptor
- getColumnfamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required bytes columnfamily_name = 3;
- getColumnfamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
required bytes columnfamily_name = 3;
- getColumnfamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
-
required bytes columnfamily_name = 3;
- getColumnFamilyName() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getColumnFamilyName() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnfamilySchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- getColumnHint() - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Used by matcher and scan/get to get a hint of the next column
to seek to after checkColumn() returns SKIP.
- getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
- getColumnHint() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
Used by matcher and scan/get to get a hint of the next column
to seek to after checkColumn() returns SKIP.
- getColumnLatest(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
- getColumnLatest(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
- getColumnLatestCell(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
The Cell for the most recent timestamp for a given column.
- getColumnLatestCell(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
The Cell for the most recent timestamp for a given column.
- getColumnLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
-
- getColumnList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- getColumnList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
repeated .Column column = 2;
- getColumnList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
repeated .Column column = 2;
- getColumnList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- getColumnList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
repeated .Column column = 1;
- getColumnList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
repeated .Column column = 1;
- getColumnName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
required bytes column_name = 2;
- getColumnName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
required bytes column_name = 2;
- getColumnName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequestOrBuilder
-
required bytes column_name = 2;
- getColumnName() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- getColumnNodeWriters() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
-
get/set
- getColumnOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnReader
-
get/set
- getColumnOffset(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getColumnOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getColumnOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
optional bytes column_offset = 3;
- getColumnOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
optional bytes column_offset = 3;
- getColumnOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
-
optional bytes column_offset = 3;
- getColumnOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- getColumnOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
repeated .Column column = 2;
- getColumnOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
repeated .Column column = 2;
- getColumnOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- getColumnOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
repeated .Column column = 1;
- getColumnOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
repeated .Column column = 1;
- getColumnOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- getColumnOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
repeated .Column column = 2;
- getColumnOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
repeated .Column column = 2;
- getColumnOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- getColumnOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
repeated .Column column = 1;
- getColumnOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
repeated .Column column = 1;
- getColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
optional bytes column_qualifier = 3;
- getColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
optional bytes column_qualifier = 3;
- getColumnQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
-
optional bytes column_qualifier = 3;
- getColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bytes column_qualifier = 2;
- getColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
optional bytes column_qualifier = 2;
- getColumnQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
optional bytes column_qualifier = 2;
- getColumns() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getColumns() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated bytes columns = 3;
- getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
repeated bytes columns = 3;
- getColumns(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
repeated bytes columns = 3;
- getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumns(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumns(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumns() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
List of columns to return, null for all columns
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
List of columns to return, null for all columns
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
List of columns to return, null for all columns
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
List of columns to return, null for all columns
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
columns to scan.
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
columns to scan.
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
the columns you want returned
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
columns to scan.
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
columns to scan.
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getColumns() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getColumnsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated bytes columns = 3;
- getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
repeated bytes columns = 3;
- getColumnsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
repeated bytes columns = 3;
- getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated bytes columns = 3;
- getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
repeated bytes columns = 3;
- getColumnsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
repeated bytes columns = 3;
- getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getColumnsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getColumnValue(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValue(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValue(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValueOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
repeated .MutationProto.ColumnValue column_value = 3;
- getColumnValues() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getColumnValues() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- getColumnValuesIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getColumnValuesIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- getColumnValuesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getColumnValuesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- getCompactedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of cells processed during minor compactions.
- getCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getCompactedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total amount of data processed during minor compactions, in bytes.
- getCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getCompaction(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
Deserialized and returns a CompactionDescriptor is the KeyValue contains one.
- getCompactionCheckMultiplier() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactionCheckMultiplier() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
- getCompactionCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompactionCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompactionInput(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_input = 4;
- getCompactionInput(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
repeated string compaction_input = 4;
- getCompactionInput(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
repeated string compaction_input = 4;
- getCompactionInputBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_input = 4;
- getCompactionInputBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
repeated string compaction_input = 4;
- getCompactionInputBytes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
repeated string compaction_input = 4;
- getCompactionInputCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_input = 4;
- getCompactionInputCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
repeated string compaction_input = 4;
- getCompactionInputCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
repeated string compaction_input = 4;
- getCompactionInputList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_input = 4;
- getCompactionInputList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
repeated string compaction_input = 4;
- getCompactionInputList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
repeated string compaction_input = 4;
- getCompactionOutput(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_output = 5;
- getCompactionOutput(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
repeated string compaction_output = 5;
- getCompactionOutput(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
repeated string compaction_output = 5;
- getCompactionOutputBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_output = 5;
- getCompactionOutputBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
repeated string compaction_output = 5;
- getCompactionOutputBytes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
repeated string compaction_output = 5;
- getCompactionOutputCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_output = 5;
- getCompactionOutputCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
repeated string compaction_output = 5;
- getCompactionOutputCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
repeated string compaction_output = 5;
- getCompactionOutputList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_output = 5;
- getCompactionOutputList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
repeated string compaction_output = 5;
- getCompactionOutputList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
repeated string compaction_output = 5;
- getCompactionPolicy() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactionPressure() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getCompactionPressure() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
This value can represent the degree of emergency of compaction for this store.
- getCompactionPressure() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
- getCompactionPressure() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getCompactionProgress() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactionProgress() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
getter for CompactionProgress object
- getCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
Returns the current size of the queue containing regions that are
processed.
- getCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the compaction queue
- getCompactionRatio() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getCompactionRatioOffPeak() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getCompactionRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCompactionRequester() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getCompactionState(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of a table.
- getCompactionState(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the current compaction state of a table.
- getCompactionState(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getCompactionState(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
optional bool compaction_state = 2;
- getCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
optional bool compaction_state = 2;
- getCompactionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequestOrBuilder
-
optional bool compaction_state = 2;
- getCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
optional .GetRegionInfoResponse.CompactionState compaction_state = 2;
- getCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
optional .GetRegionInfoResponse.CompactionState compaction_state = 2;
- getCompactionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
-
optional .GetRegionInfoResponse.CompactionState compaction_state = 2;
- getCompactionState() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCompactionState() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getCompactionStateForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the current compaction state of region.
- getCompactionStateForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get the current compaction state of region.
- getCompactionThroughputController() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getCompactionTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
-
required int64 compaction_timestamp = 1;
- getCompactionTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
required int64 compaction_timestamp = 1;
- getCompactionTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponseOrBuilder
-
required int64 compaction_timestamp = 1;
- getCompactor() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- getCompactPriority() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCompactPriority() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCompactPriority() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getCompactSplitThread() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
required .ByteArrayComparable comparable = 1;
- getComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparatorOrBuilder
-
required .ByteArrayComparable comparable = 1;
- getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
required .ByteArrayComparable comparable = 1;
- getComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparatorOrBuilder
-
required .ByteArrayComparable comparable = 1;
- getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
required .ByteArrayComparable comparable = 1;
- getComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparatorOrBuilder
-
required .ByteArrayComparable comparable = 1;
- getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- getComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
required .ByteArrayComparable comparable = 1;
- getComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparatorOrBuilder
-
required .ByteArrayComparable comparable = 1;
- getComparableBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- getComparableBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- getComparableBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- getComparableBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
required .ByteArrayComparable comparable = 1;
- getComparableOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparatorOrBuilder
-
required .ByteArrayComparable comparable = 1;
- getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
required .ByteArrayComparable comparable = 1;
- getComparableOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparatorOrBuilder
-
required .ByteArrayComparable comparable = 1;
- getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
required .ByteArrayComparable comparable = 1;
- getComparableOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparatorOrBuilder
-
required .ByteArrayComparable comparable = 1;
- getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- getComparableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
required .ByteArrayComparable comparable = 1;
- getComparableOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparatorOrBuilder
-
required .ByteArrayComparable comparable = 1;
- getComparator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- getComparator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getComparator() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getComparator() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getComparator() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required .Comparator comparator = 5;
- getComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
required .Comparator comparator = 5;
- getComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
-
required .Comparator comparator = 5;
- getComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
optional .Comparator comparator = 2;
- getComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
optional .Comparator comparator = 2;
- getComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilterOrBuilder
-
optional .Comparator comparator = 2;
- getComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
required .Comparator comparator = 4;
- getComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
required .Comparator comparator = 4;
- getComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
required .Comparator comparator = 4;
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getComparator() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getComparator() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getComparator() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
- getComparator() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getComparator() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- getComparator() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- getComparatorBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required .Comparator comparator = 5;
- getComparatorBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
optional .Comparator comparator = 2;
- getComparatorBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
required .Comparator comparator = 4;
- getComparatorClassName() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getComparatorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional string comparator_class_name = 11;
- getComparatorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional string comparator_class_name = 11;
- getComparatorClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional string comparator_class_name = 11;
- getComparatorClassNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional string comparator_class_name = 11;
- getComparatorClassNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional string comparator_class_name = 11;
- getComparatorClassNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional string comparator_class_name = 11;
- getComparatorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required .Comparator comparator = 5;
- getComparatorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
required .Comparator comparator = 5;
- getComparatorOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
-
required .Comparator comparator = 5;
- getComparatorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
optional .Comparator comparator = 2;
- getComparatorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
optional .Comparator comparator = 2;
- getComparatorOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilterOrBuilder
-
optional .Comparator comparator = 2;
- getComparatorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
required .Comparator comparator = 4;
- getComparatorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
required .Comparator comparator = 4;
- getComparatorOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
required .Comparator comparator = 4;
- getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
required .CompareFilter compare_filter = 1;
- getCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
required .CompareFilter compare_filter = 1;
- getCompareFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- getCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
required .CompareType compare_op = 1;
- getCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
required .CompareType compare_op = 1;
- getCompareOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilterOrBuilder
-
required .CompareType compare_op = 1;
- getCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
required .CompareType compare_op = 3;
- getCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
required .CompareType compare_op = 3;
- getCompareOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
required .CompareType compare_op = 3;
- getCompareType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required .CompareType compare_type = 4;
- getCompareType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
required .CompareType compare_type = 4;
- getCompareType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
-
required .CompareType compare_type = 4;
- getCompletedSnapshotDir(HBaseProtos.SnapshotDescription, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory for a specified snapshot.
- getCompletedSnapshotDir(String, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory for a completed snapshot.
- getCompletedSnapshots(RpcController, MasterProtos.GetCompletedSnapshotsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
List the currently available/stored snapshots.
- getCompletedSnapshots() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Gets the list of all completed snapshots.
- getCompletedSnapshots(RpcController, MasterProtos.GetCompletedSnapshotsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- getCompletedSnapshots(RpcController, MasterProtos.GetCompletedSnapshotsRequest, RpcCallback<MasterProtos.GetCompletedSnapshotsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc GetCompletedSnapshots(.GetCompletedSnapshotsRequest) returns (.GetCompletedSnapshotsResponse);
- getCompletedSnapshots(RpcController, MasterProtos.GetCompletedSnapshotsRequest, RpcCallback<MasterProtos.GetCompletedSnapshotsResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc GetCompletedSnapshots(.GetCompletedSnapshotsRequest) returns (.GetCompletedSnapshotsResponse);
- getCompletedSnapshots(RpcController, MasterProtos.GetCompletedSnapshotsRequest, RpcCallback<MasterProtos.GetCompletedSnapshotsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 complete_sequence_id = 15;
- getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint64 complete_sequence_id = 15;
- getCompleteSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint64 complete_sequence_id = 15;
- getCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
-
This does not really belong inside RegionLoad but its being done in the name of expediency.
- getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- getCompletionTimestamp() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getCompletionTimestamp() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
- getCompletionTimestamp() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getCompressedSize(Compression.Algorithm, Compressor, byte[], int, int) - Static method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Find the size of compressed data assuming that buffer will be compressed
using given algorithm.
- getCompression() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompression() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional string compression = 5;
- getCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
optional string compression = 5;
- getCompression() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
optional string compression = 5;
- getCompression() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getCompressionAlgorithm() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getCompressionAlgorithm() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getCompressionAlgorithmByName(String) - Static method in class org.apache.hadoop.hbase.io.compress.Compression
-
- getCompressionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional string compression = 5;
- getCompressionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
optional string compression = 5;
- getCompressionBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
optional string compression = 5;
- getCompressionCodec() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getCompressionCodec() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 compression_codec = 12;
- getCompressionCodec() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint32 compression_codec = 12;
- getCompressionCodec() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint32 compression_codec = 12;
- getCompressionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getCompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- getCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
optional .Condition condition = 3;
- getCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
optional .Condition condition = 3;
- getCondition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
-
optional .Condition condition = 3;
- getCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
optional .Condition condition = 3;
- getCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
optional .Condition condition = 3;
- getCondition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
-
optional .Condition condition = 3;
- getConditionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
optional .Condition condition = 3;
- getConditionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
optional .Condition condition = 3;
- getConditionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
optional .Condition condition = 3;
- getConditionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
optional .Condition condition = 3;
- getConditionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
-
optional .Condition condition = 3;
- getConditionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
optional .Condition condition = 3;
- getConditionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
optional .Condition condition = 3;
- getConditionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
-
optional .Condition condition = 3;
- getConf() - Method in class org.apache.hadoop.hbase.BaseConfigurable
-
- getConf() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getConf() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getConf() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
-
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Returns the current configuration.
- getConf() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
- getConf() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- getConf() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.NoOpHeapMemoryTuner
-
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
-
- getConf() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
-
- getConf() - Method in class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
-
- getConf() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- getConf() - Method in class org.apache.hadoop.hbase.tool.Canary
-
- getConf() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- getConf() - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- getConfig() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Connection
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.HTable
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.Table
-
Returns the Configuration
object used by this instance.
- getConfiguration() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
repeated .NameStringPair configuration = 3;
- getConfiguration(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
-
repeated .NameStringPair configuration = 3;
- getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
repeated .NameStringPair configuration = 2;
- getConfiguration(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptorOrBuilder
-
repeated .NameStringPair configuration = 2;
- getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
repeated .NameStringPair configuration = 4;
- getConfiguration(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .NameStringPair configuration = 4;
- getConfiguration(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- getConfiguration(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
repeated .NameStringPair configuration = 4;
- getConfiguration(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfiguration() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getConfiguration() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the configuration object required to communicate with this peer
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getConfiguration() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
Get the configuration object required to communicate with this peer
- getConfiguration() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getConfiguration(String, FilterConfig) - Method in class org.apache.hadoop.hbase.rest.filter.AuthFilter
-
Returns the configuration to be used by the authentication filter
to initialize the authentication handler.
- getConfiguration() - Method in interface org.apache.hadoop.hbase.Server
-
Gets the configuration object for this server.
- getConfiguration() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- getConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- getConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- getConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- getConfigurationBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- getConfigurationBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
repeated .NameStringPair configuration = 3;
- getConfigurationCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
-
repeated .NameStringPair configuration = 3;
- getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
repeated .NameStringPair configuration = 2;
- getConfigurationCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptorOrBuilder
-
repeated .NameStringPair configuration = 2;
- getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
repeated .NameStringPair configuration = 4;
- getConfigurationCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .NameStringPair configuration = 4;
- getConfigurationCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
repeated .NameStringPair configuration = 4;
- getConfigurationCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
repeated .NameStringPair configuration = 3;
- getConfigurationList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
-
repeated .NameStringPair configuration = 3;
- getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
repeated .NameStringPair configuration = 2;
- getConfigurationList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptorOrBuilder
-
repeated .NameStringPair configuration = 2;
- getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
repeated .NameStringPair configuration = 4;
- getConfigurationList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .NameStringPair configuration = 4;
- getConfigurationList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
repeated .NameStringPair configuration = 4;
- getConfigurationList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfigurationManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
repeated .NameStringPair configuration = 3;
- getConfigurationOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
-
repeated .NameStringPair configuration = 3;
- getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
repeated .NameStringPair configuration = 2;
- getConfigurationOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptorOrBuilder
-
repeated .NameStringPair configuration = 2;
- getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
repeated .NameStringPair configuration = 3;
- getConfigurationOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
-
repeated .NameStringPair configuration = 3;
- getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
repeated .NameStringPair configuration = 2;
- getConfigurationOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptorOrBuilder
-
repeated .NameStringPair configuration = 2;
- getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
repeated .NameStringPair configuration = 4;
- getConfigurationOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
repeated .NameStringPair configuration = 4;
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Getter for accessing the configuration value by key.
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Getter for accessing the configuration value by key
- getConfigurationValue(String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
Getter for accessing the configuration value by key
- getConnection() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getConnection() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getConnection() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- getConnection() - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
This method will be changed from public to package protected.
- getConnection() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- getConnection(User, Call, InetSocketAddress) - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl
-
Get a connection from the pool, or create a new one and add it to the
pool.
- getConnection(SocketChannel, long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Subclasses of HBaseServer can override this to provide their own
Connection implementations.
- getConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getConnection() - Method in interface org.apache.hadoop.hbase.Server
-
Returns a reference to the servers' cluster connection.
- getConnectionConfiguration() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- getConnectionForEnvironment(CoprocessorEnvironment) - Static method in class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
Create an unmanaged
HConnection
based on the environment in which we are running the
coprocessor.
- getConnectionHashCode() - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
-
- getConnectorAddress(int) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Get the address that corresponds to a particular connector.
- getConsistency() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns the consistency level for this operation
- getConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .Consistency consistency = 12 [default = STRONG];
- getConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional .Consistency consistency = 12 [default = STRONG];
- getConsistency() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional .Consistency consistency = 12 [default = STRONG];
- getConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .Consistency consistency = 16 [default = STRONG];
- getConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional .Consistency consistency = 16 [default = STRONG];
- getConsistency() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional .Consistency consistency = 16 [default = STRONG];
- getContext() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
-
- getContext(Class<?>) - Method in class org.apache.hadoop.hbase.rest.provider.JAXBContextResolver
-
- getCoordinatedStateManager(Configuration) - Static method in class org.apache.hadoop.hbase.CoordinatedStateManagerFactory
-
Creates consensus provider from the given configuration.
- getCoordinatedStateManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getCoordinatedStateManager() - Method in interface org.apache.hadoop.hbase.Server
-
Get CoordinatedStateManager instance for this server.
- getCoprocessorExecutionStatistics() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the time spent by coprocessors in this region.
- getCoprocessorExecutionStatistics() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getCoprocessorExecutionStatistics() - Method in class org.apache.hadoop.hbase.regionserver.RegionCoprocessorHost
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getCoprocessorHost() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
- getCoprocessors() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
Used to create a parameter to the HServerLoad constructor so that
HServerLoad can provide information about the coprocessors loaded by this
regionserver.
- getCoprocessors() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Return the list of attached co-processor represented by their name className
- getCoprocessors() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the co-processors
- getCoprocessors() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getCoprocessors(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessors(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessors(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessors() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the co-processors
- getCoprocessorsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .Coprocessor coprocessors = 6;
- getCoprocessorsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .Coprocessor coprocessors = 6;
- getCorePoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getCorePoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getCorrupted() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getCorruptedLogs() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- getCorruptedStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
-
required int64 count = 1 [default = 0];
- getCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
required int64 count = 1 [default = 0];
- getCount() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponseOrBuilder
-
required int64 count = 1 [default = 0];
- getCount() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getCount() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Returns the number of items that the estimator has processed
- getCountersMapSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getCountersMapSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required uint64 create_time = 3;
- getCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
required uint64 create_time = 3;
- getCreateTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
-
required uint64 create_time = 3;
- getCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional int64 create_time = 6;
- getCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional int64 create_time = 6;
- getCreateTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional int64 create_time = 6;
- getCreateTime() - Method in class org.apache.hadoop.hbase.RegionTransition
-
- getCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
optional int64 creation_time = 3 [default = 0];
- getCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
optional int64 creation_time = 3 [default = 0];
- getCreationTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
optional int64 creation_time = 3 [default = 0];
- getCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional int64 creation_time = 3 [default = 0];
- getCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
optional int64 creation_time = 3 [default = 0];
- getCreationTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
optional int64 creation_time = 3 [default = 0];
- getCurBlockCacheSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getCurMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getCurrent() - Static method in class org.apache.hadoop.hbase.security.User
-
Returns the User
instance within current execution context.
- getCurrent() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
- getCurrentCall() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Needed for features such as delayed calls.
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 current_compacted_KVs = 11;
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint64 current_compacted_KVs = 11;
- getCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint64 current_compacted_KVs = 11;
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getCurrentCompactedKvs() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 currentCompactedKVs = 13;
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int64 currentCompactedKVs = 13;
- getCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int64 currentCompactedKVs = 13;
- getCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getCurrentFileName() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
This is a convenience method that computes a new filename with a given
using the current WAL file-number
- getCurrentFileName(WAL) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
return the current filename from the current wal.
- getCurrentFileSystem(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getCurrentHour() - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CurrentHourProvider
-
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Returns the current key.
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Returns the current key.
- getCurrentKey() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- getCurrentNrHRS() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
This method will be changed from public to package protected.
- getCurrentPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getCurrentPath() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get the current log that's replicated
- getCurrentPoolSize(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
- getCurrentSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the occupied size of the block cache, in bytes.
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getCurrentSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getCurrentUserName() - Method in class org.apache.hadoop.hbase.security.UserProvider
-
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Returns the current value.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Returns the current value.
- getCurrentValue() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- getCurTaskZKVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- getData() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required bytes data = 3;
- getData() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
required bytes data = 3;
- getData() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
-
required bytes data = 3;
- getData(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- getData(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
repeated .BytesBytesPair data = 3;
- getData(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
repeated .BytesBytesPair data = 3;
- getData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional bytes data = 4;
- getData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
optional bytes data = 4;
- getData() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
optional bytes data = 4;
- getData(String, Watcher, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getData is an idempotent operation.
- getData(String, boolean, Stat) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
getData is an idemnpotent operation.
- getData(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the current data in the unassigned node for the specified region name
or fully-qualified path.
- getData(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get znode data.
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
-
- getData() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
-
- getData(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Gets the data of the node.
- getDataAndWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the current data in the unassigned node for the specified region name
or fully-qualified path.
- getDataAndWatch(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode and set a watch.
- getDataAndWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode and set a watch.
- getDataBlockEncoder() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getDataBlockEncoder() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getDataBlockEncoderById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Find and create data block encoder for given id;
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getDataBlockEncoding() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- getDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- getDataBlockEncodingId() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getDataBlockEncodingOnDisk() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getDataBlockIndexReader() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getDataBlockIndexReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getDataBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- getDataBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- getDataCount() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getDataCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- getDataCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
repeated .BytesBytesPair data = 3;
- getDataCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
repeated .BytesBytesPair data = 3;
- getDataIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getDataIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 data_index_count = 5;
- getDataIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint32 data_index_count = 5;
- getDataIndexCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint32 data_index_count = 5;
- getDataInMemoryWithoutWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getDataInMemoryWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Ammount of data in the memstore but not in the WAL because mutations explicitly had their
WAL turned off.
- getDataInMemoryWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getDataList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- getDataList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
repeated .BytesBytesPair data = 3;
- getDataList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
repeated .BytesBytesPair data = 3;
- getDataLocality() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional float data_locality = 16;
- getDataLocality() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional float data_locality = 16;
- getDataLocality() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional float data_locality = 16;
- getDataLocality() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getDataNoWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the current data in the unassigned node for the specified region name
or fully-qualified path.
- getDataNoWatch(ZooKeeperWatcher, String, Stat) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the data at the specified znode without setting a watch.
- getDataOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- getDataOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
repeated .BytesBytesPair data = 3;
- getDataOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
repeated .BytesBytesPair data = 3;
- getDataOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- getDataOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
repeated .BytesBytesPair data = 3;
- getDataOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
repeated .BytesBytesPair data = 3;
- getDataSetWatchAsync() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- getDataSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getDataToWriteToZooKeeper(Map<String, Integer>) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
Creates the labels data to be written to zookeeper.
- getDataWriter() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Get a writable interface into bloom filter data (the actual Bloom bits).
- getDataWriter() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getDataWriter() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- getDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string date = 5;
- getDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string date = 5;
- getDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string date = 5;
- getDate() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
The date that hbase was compiled.
- getDateBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string date = 5;
- getDateBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string date = 5;
- getDateBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string date = 5;
- getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
- getDaughterRegions(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the daughter regions by reading the corresponding columns of the catalog table
Result.
- getDeadline(RPCProtos.RequestHeader, Message) - Method in interface org.apache.hadoop.hbase.ipc.PriorityFunction
-
Returns the deadline of the specified request.
- getDeadline(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getDeadNode(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getDeadNodes() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getDeadNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated string deadNodes = 2;
- getDeadNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
repeated string deadNodes = 2;
- getDeadNodes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
repeated string deadNodes = 2;
- getDeadNodesBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated string deadNodes = 2;
- getDeadNodesBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
repeated string deadNodes = 2;
- getDeadNodesBytes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
repeated string deadNodes = 2;
- getDeadNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated string deadNodes = 2;
- getDeadNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
repeated string deadNodes = 2;
- getDeadNodesCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
repeated string deadNodes = 2;
- getDeadNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated string deadNodes = 2;
- getDeadNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
repeated string deadNodes = 2;
- getDeadNodesList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
repeated string deadNodes = 2;
- getDeadRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the dead region servers
- getDeadRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getDeadRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- getDeadServerNames() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getDeadServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getDeadServers(long) - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
Get the servers which died since a given timestamp.
- getDeadServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getDeadServers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- getDeadServers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .ServerName dead_servers = 3;
- getDeadServers(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .ServerName dead_servers = 3;
- getDeadServers() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getDeadServers__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getDeadServersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- getDeadServersBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- getDeadServersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- getDeadServersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .ServerName dead_servers = 3;
- getDeadServersCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .ServerName dead_servers = 3;
- getDeadServersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- getDeadServersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .ServerName dead_servers = 3;
- getDeadServersList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .ServerName dead_servers = 3;
- getDeadServersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- getDeadServersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .ServerName dead_servers = 3;
- getDeadServersOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .ServerName dead_servers = 3;
- getDeadServersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- getDeadServersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .ServerName dead_servers = 3;
- getDeadServersOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .ServerName dead_servers = 3;
- getDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string declaring_class = 1;
- getDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
optional string declaring_class = 1;
- getDeclaringClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
optional string declaring_class = 1;
- getDeclaringClassBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string declaring_class = 1;
- getDeclaringClassBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
optional string declaring_class = 1;
- getDeclaringClassBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
optional string declaring_class = 1;
- getDecodabet(int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Returns one of the _SOMETHING_DECODABET byte arrays depending on the
options specified.
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodec
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodecWithTags
-
- getDecoder(InputStream) - Method in interface org.apache.hadoop.hbase.codec.Codec
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.codec.MessageCodec
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- getDecoder(InputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getDecompressor() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getDecryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return a decryptor for decrypting data.
- getDefaultBlockDecodingContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReader
-
Get the default decoder for blocks from this file.
- getDefaultBlockSize(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Return the number of bytes that large input files should be optimally
be split into to minimize i/o time.
- getDefaultBufferSize(FileSystem) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the default buffer size to use during writes.
- getDefaultCodec(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- getDefaultDetails() - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
- getDefaultDetails() - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
-
- getDefaultDetails() - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
- getDefaultDetails() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
-
- getDefaultExecutor(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- getDefaultHost(String, String) - Static method in class org.apache.hadoop.hbase.util.DNS
-
Wrapper around DNS.getDefaultHost(String, String), calling
DNS.getDefaultHost(String, String, boolean) when available.
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getDefaultInstance() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- getDefaultInstanceForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getDefaultLoadBalancerClass() - Static method in class org.apache.hadoop.hbase.master.balancer.LoadBalancerFactory
-
- getDefaultRegionLocation() - Method in class org.apache.hadoop.hbase.RegionLocations
-
- getDefaultReplication(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getDefaultValues() - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getDelegate() - Static method in class org.apache.hadoop.hbase.util.EnvironmentEdgeManager
-
Retrieves the singleton instance of the
EnvironmentEdge
that is
being managed.
- getDelegatesForTesting() - Method in class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
Exposed for TESTING!
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
-
- getDeletableFiles(Iterable<FileStatus>) - Method in interface org.apache.hadoop.hbase.master.cleaner.FileCleanerDelegate
-
Determines which of the given files are safe to delete
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
- getDeletableFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- getDeleteBloomFilterMetadata() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Retrieves delete family Bloom filter metadata as appropriate for each
HFile
version.
- getDeleteBloomFilterMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- getDeleteColumnFamilyInModify() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required bool delete_column_family_in_modify = 4;
- getDeleteColumnFamilyInModify() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
required bool delete_column_family_in_modify = 4;
- getDeleteColumnFamilyInModify() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
-
required bool delete_column_family_in_modify = 4;
- getDeleted(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 deleted = 3;
- getDeleted(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
repeated uint64 deleted = 3;
- getDeleted(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNodeOrBuilder
-
repeated uint64 deleted = 3;
- getDeletedCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 deleted = 3;
- getDeletedCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
repeated uint64 deleted = 3;
- getDeletedCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNodeOrBuilder
-
repeated uint64 deleted = 3;
- getDeletedList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 deleted = 3;
- getDeletedList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
repeated uint64 deleted = 3;
- getDeletedList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNodeOrBuilder
-
repeated uint64 deleted = 3;
- getDeleteFamilyCnt() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getDeletes() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
list of TDeletes to delete
- getDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
the TDelete to execute if the check succeeds
- getDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
the TDelete to delete
- getDeleteSingle() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- getDeletesIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- getDeletesSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- getDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required .BulkDeleteRequest.DeleteType deleteType = 2;
- getDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
required .BulkDeleteRequest.DeleteType deleteType = 2;
- getDeleteType() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
-
required .BulkDeleteRequest.DeleteType deleteType = 2;
- getDeleteType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional .MutationProto.DeleteType delete_type = 4;
- getDeleteType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
optional .MutationProto.DeleteType delete_type = 4;
- getDeleteType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
-
optional .MutationProto.DeleteType delete_type = 4;
- getDeleteType() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getDelimitedMessageAsByteBuffer(Message) - Static method in class org.apache.hadoop.hbase.ipc.IPCUtil
-
- getDelimiter(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- getDelimiterInReverse(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Find index of passed delimiter walking from end of buffer backwards.
- getDelta(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.master_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.snapshot_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.table_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.tablesDetailed_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.master.zk_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.regionserver.regionserver_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.rest.rest_jsp
-
- getDependants() - Method in class org.apache.hadoop.hbase.generated.thrift.thrift_jsp
-
- getDesc(List<Throwable>, List<? extends Row>, List<String>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getDesc(Map<String, Integer>) - Static method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getDescription() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Type
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellType
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Consistency
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Durability
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeUnit
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.State
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureState
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaScope
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaType
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleType
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Type
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.FlushAction
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.EventType
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.ScopeType
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.RecoveryMode
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
- getDescriptor() - Static method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- getDescriptor() - Static method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Type
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellType
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Consistency
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Durability
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeUnit
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyState
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableState
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyState
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableState
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableState
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableState
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyState
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableState
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableState
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.State
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureState
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaScope
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaType
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleType
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Type
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.FlushAction
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.EventType
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.ScopeType
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.RecoveryMode
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
-
- getDescriptorForType() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
- getDescriptorForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
- getDeserialiserIdentifier() - Method in interface org.apache.hadoop.hbase.io.hfile.CacheableDeserializer
-
Get the identifier of this deserialiser.
- getDeserializer() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Returns CacheableDeserializer instance which reconstructs original object from ByteBuffer.
- getDeserializer(int) - Static method in class org.apache.hadoop.hbase.io.hfile.CacheableDeserializerIdManager
-
Get the cacheable deserializer as the given identifier Id
- getDeserializer() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getDeserializer(Class<KeyValue>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
-
- getDeserializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- getDeserializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- getDestination() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Get the destination server for the plan for this region.
- getDestinationServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional .ServerName destination_server = 4;
- getDestinationServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
optional .ServerName destination_server = 4;
- getDestinationServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
-
optional .ServerName destination_server = 4;
- getDestinationServerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional .ServerName destination_server = 4;
- getDestinationServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional .ServerName destination_server = 4;
- getDestinationServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
optional .ServerName destination_server = 4;
- getDestinationServerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
-
optional .ServerName destination_server = 4;
- getDestServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
optional .ServerName dest_server_name = 2;
- getDestServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
optional .ServerName dest_server_name = 2;
- getDestServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequestOrBuilder
-
optional .ServerName dest_server_name = 2;
- getDestServerNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
optional .ServerName dest_server_name = 2;
- getDestServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
optional .ServerName dest_server_name = 2;
- getDestServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
optional .ServerName dest_server_name = 2;
- getDestServerNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequestOrBuilder
-
optional .ServerName dest_server_name = 2;
- getDetails() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Returns the configuration that was provided previously
- getDetails() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- getDetailsForNonCoordinatedOpening() - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination
-
Get details object with params for case when we're opening on
regionserver side with all "default" properties.
- getDetailsForNonCoordinatedOpening() - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination
-
No ZK tracking will be performed for that case.
- getDetaultDetails() - Method in interface org.apache.hadoop.hbase.coordination.CloseRegionCoordination
-
Get details object with params for case when we're closing on
regionserver side internally (not because of RPC call from master),
so we don't parse details from protobuf request.
- getDetaultDetails() - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination
-
No ZK tracking will be performed for that case.
- getDeterministicRandomSeed(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Creates a deterministic hash code for store file collection.
- getDifference() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
-
get/set
- getDirectMemorySize() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
- getDirectMemoryUsage() - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
- getDisabledOrDisablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
-
Gets a list of all the tables set as disabled in zookeeper.
- getDisabledTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
-
Gets a list of all the tables set as disabled in zookeeper.
- getDispersionInformation() - Method in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- getDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
optional bool done = 1 [default = false];
- getDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
optional bool done = 1 [default = false];
- getDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponseOrBuilder
-
optional bool done = 1 [default = false];
- getDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
-
optional bool done = 1 [default = false];
- getDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
optional bool done = 1 [default = false];
- getDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponseOrBuilder
-
optional bool done = 1 [default = false];
- getDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
optional bool done = 1 [default = false];
- getDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
optional bool done = 1 [default = false];
- getDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponseOrBuilder
-
optional bool done = 1 [default = false];
- getDoNotRetry() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional bool do_not_retry = 5;
- getDoNotRetry() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional bool do_not_retry = 5;
- getDoNotRetry() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional bool do_not_retry = 5;
- getDoubleMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
-
required double double_msg = 1;
- getDoubleMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
required double double_msg = 1;
- getDoubleMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsgOrBuilder
-
required double double_msg = 1;
- getDrainingServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getDropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getDropDependentColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
optional bool drop_dependent_column = 4;
- getDropDependentColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
optional bool drop_dependent_column = 4;
- getDropDependentColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
-
optional bool drop_dependent_column = 4;
- getDummyHeaderForVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Return the appropriate DUMMY_HEADER for the minor version
- getDumpServlet() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getDumpServlet() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getDurability() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Get the current durability
- getDurability() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the durability setting for the table.
- getDurability() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .MutationProto.Durability durability = 6 [default = USE_DEFAULT];
- getDurability() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional .MutationProto.Durability durability = 6 [default = USE_DEFAULT];
- getDurability() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional .MutationProto.Durability durability = 6 [default = USE_DEFAULT];
- getDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- getDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getDurability() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getEarliestFlushTimeForAllStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getEarliestFlushTimeForAllStores() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getEarliestMemstoreSeqNum(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getEarliestMemstoreSeqNum(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getEarliestMemstoreSeqNum(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
- getEarliestMemstoreSeqNum(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Gets the earliest sequence number in the memstore for this particular region and store.
- getEdit() - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
-
Gets the edit
- getEffectiveDataBlockEncoding() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- getEffectiveDurability(Durability) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Returns effective durability from the passed durability and
the table descriptor.
- getEffectiveEncodingInCache(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
- getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- getEffectiveEncodingInCache(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- getEffectiveUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
required string effective_user = 1;
- getEffectiveUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
required string effective_user = 1;
- getEffectiveUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformationOrBuilder
-
required string effective_user = 1;
- getEffectiveUser() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Get the current thread local effective user
- getEffectiveUserBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
required string effective_user = 1;
- getEffectiveUserBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
required string effective_user = 1;
- getEffectiveUserBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformationOrBuilder
-
required string effective_user = 1;
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.append
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.atomicIncrement
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.checkAndPut
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.compact
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.createTable
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAll
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRow
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRowTs
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllTs
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteTable
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.disableTable
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.enableTable
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.get
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getColumnDescriptors
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRegionInfo
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRow
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowOrBefore
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRows
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsTs
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumns
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumnsTs
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowTs
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumns
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumnsTs
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableNames
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableRegions
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVer
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVerTs
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.increment
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.incrementRows
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.isTableEnabled
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.majorCompact
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRow
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRows
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowsTs
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowTs
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerClose
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGet
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGetList
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpen
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenTs
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithPrefix
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithScan
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStop
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStopTs
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.append
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndDelete
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndPut
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.closeScanner
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteMultiple
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteSingle
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.exists
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.get
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getMultiple
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerResults
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerRows
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.increment
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.mutateRow
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.openScanner
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.put
-
- getEmptyArgsInstance() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.putMultiple
-
- getEnable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
-
required bool enable = 1;
- getEnable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
required bool enable = 1;
- getEnable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequestOrBuilder
-
required bool enable = 1;
- getEnabled() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
-
required bool enabled = 1;
- getEnabled() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
required bool enabled = 1;
- getEnabled() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponseOrBuilder
-
required bool enabled = 1;
- getEnablingTables(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateClientSideReader
-
Gets a list of all the tables set as enabling in zookeeper.
- getEncodedCompressedSize(Compression.Algorithm, Compressor) - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Estimate size after second stage of compression (e.g.
- getEncodedName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getEncodedNameAsBytes() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getEncodedNodeName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
Gets the full path node name for the log file being split.
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required bytes encoded_region_name = 2;
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
required bytes encoded_region_name = 2;
- getEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
-
required bytes encoded_region_name = 2;
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required bytes encoded_region_name = 2;
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
required bytes encoded_region_name = 2;
- getEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
required bytes encoded_region_name = 2;
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
required bytes encoded_region_name = 3;
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
required bytes encoded_region_name = 3;
- getEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
required bytes encoded_region_name = 3;
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
required bytes encoded_region_name = 3;
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
required bytes encoded_region_name = 3;
- getEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
required bytes encoded_region_name = 3;
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required bytes encoded_region_name = 1;
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
required bytes encoded_region_name = 1;
- getEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
required bytes encoded_region_name = 1;
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getEncodedRegionName() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
-
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodec
-
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.CellCodecWithTags
-
- getEncoder(OutputStream) - Method in interface org.apache.hadoop.hbase.codec.Codec
-
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodec
-
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
-
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.codec.MessageCodec
-
- getEncoder() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Return new data block encoder for given algorithm type.
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- getEncoder(OutputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- getEncodingById(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- getEncodingCountsForTest() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getEncodingState() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- getEncodingState() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
- getEncryptionContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Return the raw crypto key attribute for the family, or null if not set
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional bytes encryption_key = 13;
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional bytes encryption_key = 13;
- getEncryptionKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional bytes encryption_key = 13;
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional bytes encryption_key = 2;
- getEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
optional bytes encryption_key = 2;
- getEncryptionKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
-
optional bytes encryption_key = 2;
- getEncryptionType() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Return the encryption algorithm in use by this family
- getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getEncryptor() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Get an encryptor for encrypting data.
- getEnd() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getEnd() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- getEndKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getEndKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bytes end_key = 4;
- getEndKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
optional bytes end_key = 4;
- getEndKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
optional bytes end_key = 4;
- getEndKey() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- getEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional bytes endKey = 3;
- getEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
optional bytes endKey = 3;
- getEndKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
optional bytes endKey = 3;
- getEndKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getEndKey() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getEndKey() - Method in interface org.apache.hadoop.hbase.util.KeyRange
-
- getEndKeys() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
Gets the ending row key for every region in the currently open table.
- getEndKeys() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the ending row key for every region in the currently open table.
- getEndRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getEndRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the end row.
- getEndRow(int) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
Gets the end row for a given stripe.
- getEndRow(int) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getEndRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional bytes endRow = 2;
- getEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional bytes endRow = 2;
- getEndRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional bytes endRow = 2;
- getEndRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getEndTime() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int64 endTime = 6;
- getEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional int64 endTime = 6;
- getEndTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional int64 endTime = 6;
- getEndTime() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getEngine() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
optional string engine = 4;
- getEngine() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
optional string engine = 4;
- getEngine() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
-
optional string engine = 4;
- getEngineBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
optional string engine = 4;
- getEngineBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
optional string engine = 4;
- getEngineBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
-
optional string engine = 4;
- getEntries() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getEntries() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getEntries() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getEntries() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getEntries() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- getEntry(short) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
Gets an entry from the dictionary.
- getEntry(short) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
-
- getEntry(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- getEntry(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
repeated .WALEntry entry = 1;
- getEntry(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequestOrBuilder
-
repeated .WALEntry entry = 1;
- getEntryBuffer() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
-
- getEntryBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- getEntryBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- getEntryCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- getEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
repeated .WALEntry entry = 1;
- getEntryCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequestOrBuilder
-
repeated .WALEntry entry = 1;
- getEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 entry_count = 7;
- getEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 entry_count = 7;
- getEntryCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 entry_count = 7;
- getEntryList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- getEntryList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
repeated .WALEntry entry = 1;
- getEntryList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequestOrBuilder
-
repeated .WALEntry entry = 1;
- getEntryOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- getEntryOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
repeated .WALEntry entry = 1;
- getEntryOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequestOrBuilder
-
repeated .WALEntry entry = 1;
- getEntryOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- getEntryOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
repeated .WALEntry entry = 1;
- getEntryOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequestOrBuilder
-
repeated .WALEntry entry = 1;
- getEnvironment() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
- getEnvironment() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getErr() - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
-
- getErrorHandler() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getErrorHandler() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- getErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional bytes error_info = 3;
- getErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
optional bytes error_info = 3;
- getErrorInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
optional bytes error_info = 3;
- getErrorList() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- getErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
optional string error_message = 1;
- getErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
optional string error_message = 1;
- getErrorMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponseOrBuilder
-
optional string error_message = 1;
- getErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required string error_message = 2;
- getErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
required string error_message = 2;
- getErrorMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
-
required string error_message = 2;
- getErrorMessageBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
optional string error_message = 1;
- getErrorMessageBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
optional string error_message = 1;
- getErrorMessageBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponseOrBuilder
-
optional string error_message = 1;
- getErrorMessageBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required string error_message = 2;
- getErrorMessageBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
required string error_message = 2;
- getErrorMessageBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
-
required string error_message = 2;
- getErrorMonitor() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Get the ForeignExceptionDispatcher
- getErrorRate(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- getErrors() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getEstimatedNumberOfKvsScanned() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- getEventType() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Return the event type
- getEventType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
required .RegionEventDescriptor.EventType event_type = 1;
- getEventType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
required .RegionEventDescriptor.EventType event_type = 1;
- getEventType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
required .RegionEventDescriptor.EventType event_type = 1;
- getEventType() - Method in class org.apache.hadoop.hbase.RegionTransition
-
- getEventTypeCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required uint32 event_type_code = 1;
- getEventTypeCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
required uint32 event_type_code = 1;
- getEventTypeCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
-
required uint32 event_type_code = 1;
- getEvictCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getEvictedCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getEvictionCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getException(byte[]) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- getException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- getException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
-
Get the value of the captured exception.
- getException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getException() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getException() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
optional .NameBytesPair exception = 2;
- getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
optional .NameBytesPair exception = 2;
- getException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResultOrBuilder
-
optional .NameBytesPair exception = 2;
- getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .NameBytesPair exception = 3;
- getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional .NameBytesPair exception = 3;
- getException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional .NameBytesPair exception = 3;
- getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional .ForeignExceptionMessage exception = 5;
- getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
optional .ForeignExceptionMessage exception = 5;
- getException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
-
optional .ForeignExceptionMessage exception = 5;
- getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional .ForeignExceptionMessage exception = 10;
- getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional .ForeignExceptionMessage exception = 10;
- getException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional .ForeignExceptionMessage exception = 10;
- getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .ExceptionResponse exception = 2;
- getException() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
optional .ExceptionResponse exception = 2;
- getException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
-
optional .ExceptionResponse exception = 2;
- getException() - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
-
Get the last exception which has occurred when re-setting the watch.
- getExceptionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
optional .NameBytesPair exception = 2;
- getExceptionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .NameBytesPair exception = 3;
- getExceptionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional .ForeignExceptionMessage exception = 5;
- getExceptionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional .ForeignExceptionMessage exception = 10;
- getExceptionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .ExceptionResponse exception = 2;
- getExceptionCause() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getExceptionClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string exception_class_name = 1;
- getExceptionClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional string exception_class_name = 1;
- getExceptionClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional string exception_class_name = 1;
- getExceptionClassNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string exception_class_name = 1;
- getExceptionClassNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional string exception_class_name = 1;
- getExceptionClassNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional string exception_class_name = 1;
- getExceptionFullMessage() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- getExceptionIfFailed() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getExceptionIfFailed() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
Get the exception that caused the snapshot to fail, if the snapshot has failed.
- getExceptionMessage() - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- getExceptionMessage() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
-
- getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- getExceptionMessageAdditionalDetail() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getExceptionMessageAdditionalDetail() - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
-
- getExceptionMsg() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
- getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
optional .NameBytesPair exception = 2;
- getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
optional .NameBytesPair exception = 2;
- getExceptionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResultOrBuilder
-
optional .NameBytesPair exception = 2;
- getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .NameBytesPair exception = 3;
- getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional .NameBytesPair exception = 3;
- getExceptionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional .NameBytesPair exception = 3;
- getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional .ForeignExceptionMessage exception = 5;
- getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
optional .ForeignExceptionMessage exception = 5;
- getExceptionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
-
optional .ForeignExceptionMessage exception = 5;
- getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional .ForeignExceptionMessage exception = 10;
- getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional .ForeignExceptionMessage exception = 10;
- getExceptionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional .ForeignExceptionMessage exception = 10;
- getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .ExceptionResponse exception = 2;
- getExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
optional .ExceptionResponse exception = 2;
- getExceptionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
-
optional .ExceptionResponse exception = 2;
- getExceptions() - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- getExecuted() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
-
required bool executed = 1;
- getExecuted() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
required bool executed = 1;
- getExecuted() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureDataOrBuilder
-
required bool executed = 1;
- getExecutor() - Method in class org.apache.hadoop.metrics2.lib.MetricsExecutorImpl
-
- getExecutor() - Method in interface org.apache.hadoop.metrics2.MetricsExecutor
-
- getExecutorService() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getExecutorService() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getExecutorService() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getExhaustiveDescription() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getExist() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- getExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional bool existence_only = 10 [default = false];
- getExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional bool existence_only = 10 [default = false];
- getExistenceOnly() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional bool existence_only = 10 [default = false];
- getExistingAssignmentPlan() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get the favored nodes plan
- getExistingLabelsWithAuths() - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getExists() - Method in class org.apache.hadoop.hbase.client.Result
-
- getExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional bool exists = 3;
- getExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
optional bool exists = 3;
- getExists() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
optional bool exists = 3;
- getExistsResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
optional int64 expected_timeout = 1;
- getExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
optional int64 expected_timeout = 1;
- getExpectedTimeout() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponseOrBuilder
-
optional int64 expected_timeout = 1;
- getExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
-
required int64 expected_timeout = 1;
- getExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
required int64 expected_timeout = 1;
- getExpectedTimeout() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponseOrBuilder
-
required int64 expected_timeout = 1;
- getExpectedVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
-
- getExpiration() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- getExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
required int64 expiration_date = 2;
- getExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
required int64 expiration_date = 2;
- getExpirationDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
-
required int64 expiration_date = 2;
- getExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
optional int64 expiration_date = 5;
- getExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
optional int64 expiration_date = 5;
- getExpirationDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
-
optional int64 expiration_date = 5;
- getExpirationDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getExpression() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
required string expression = 1;
- getExpression() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
required string expression = 1;
- getExpression() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibilityOrBuilder
-
required string expression = 1;
- getExpression() - Method in class org.apache.hadoop.hbase.security.visibility.CellVisibility
-
- getExpression() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
-
- getExpressionBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
required string expression = 1;
- getExpressionBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
required string expression = 1;
- getExpressionBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibilityOrBuilder
-
required string expression = 1;
- getExtraHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Get an extra header value.
- getExtraHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Get all extra headers (read-only).
- getFailedBlockAdditions() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getFailedCounterForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getFailedDeletions() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
- getFailedIncrements() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getFailedIncrements() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getFailedOn() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
Returns any exception thrown during service method invocation, or null
if no exception
was thrown.
- getFailureCount() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
- getFailures() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getFamilies() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns an unmodifiable collection of all the
HColumnDescriptor
of all the column families of the table.
- getFamilies() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getFamiliesKeys() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns all the column family names of the current table.
- getFamily() - Method in interface org.apache.hadoop.hbase.Cell
-
- getFamily() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getFamily() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getFamily() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the HColumnDescriptor for a specific column family with name as
specified by the parameter column.
- getFamily() - Method in class org.apache.hadoop.hbase.KeyValue
-
Deprecated.
- getFamily(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getFamily() - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column family used for meta columns.
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional bytes family = 2;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
optional bytes family = 2;
- getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
-
optional bytes family = 2;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
optional bytes family = 3;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
optional bytes family = 3;
- getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
-
optional bytes family = 3;
- getFamily(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
repeated bytes family = 2;
- getFamily(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
repeated bytes family = 2;
- getFamily(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
-
repeated bytes family = 2;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes family = 2;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional bytes family = 2;
- getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional bytes family = 2;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
required bytes family = 2;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
required bytes family = 2;
- getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
required bytes family = 2;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
required bytes family = 1;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
required bytes family = 1;
- getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder
-
required bytes family = 1;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
required bytes family = 1;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
required bytes family = 1;
- getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ColumnOrBuilder
-
required bytes family = 1;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required bytes family = 2;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
required bytes family = 2;
- getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
-
required bytes family = 2;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
required bytes family = 1;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
required bytes family = 1;
- getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
-
required bytes family = 1;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
required bytes family = 1;
- getFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
required bytes family = 1;
- getFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScopeOrBuilder
-
required bytes family = 1;
- getFamily() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFamily() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getFamily() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getFamily() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getFamily() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getFamily() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
Deprecated.
- getFamily() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
column name
- getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
column family to check
- getFamily() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
column family to check
- getFamilyArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous bytes composed of legal HDFS filename characters which may start at any index in the
containing array.
- getFamilyArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getFamilyArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getFamilyCellMap() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the put's familyMap
- getFamilyCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
repeated bytes family = 2;
- getFamilyCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
repeated bytes family = 2;
- getFamilyCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
-
repeated bytes family = 2;
- getFamilyDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Given a particular region dir, return all the familydirs inside it
- getFamilyFiles(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFiles(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFiles(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifestOrBuilder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifestOrBuilder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifestOrBuilder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifestOrBuilder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyFilesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifestOrBuilder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- getFamilyLength() - Method in interface org.apache.hadoop.hbase.Cell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getFamilyLength(int) - Method in class org.apache.hadoop.hbase.KeyValue
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getFamilyLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getFamilyList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
repeated bytes family = 2;
- getFamilyList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
repeated bytes family = 2;
- getFamilyList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
-
repeated bytes family = 2;
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's familyMap
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getFamilyMap(byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Map of qualifiers to values.
- getFamilyMap() - Method in class org.apache.hadoop.hbase.client.Scan
-
Getting the familyMap
- getFamilyMapOfLongs() - Method in class org.apache.hadoop.hbase.client.Increment
-
Before 0.95, when you called Increment#getFamilyMap(), you got back
a map of families to a list of Longs.
- getFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
required bytes family_name = 1;
- getFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
required bytes family_name = 1;
- getFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceIdOrBuilder
-
required bytes family_name = 1;
- getFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
required bytes family_name = 1;
- getFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
required bytes family_name = 1;
- getFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFilesOrBuilder
-
required bytes family_name = 1;
- getFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required bytes family_name = 3;
- getFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
required bytes family_name = 3;
- getFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
required bytes family_name = 3;
- getFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
required bytes family_name = 1;
- getFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
required bytes family_name = 1;
- getFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptorOrBuilder
-
required bytes family_name = 1;
- getFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
required bytes family_name = 1;
- getFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
required bytes family_name = 1;
- getFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptorOrBuilder
-
required bytes family_name = 1;
- getFamilyOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getFamilyOffset(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getFamilyOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getFamilyOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getFamilyPath(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPath(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPath(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPath(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPath(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPath(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- getFamilyPathOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilyPathOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- getFamilySorter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getFamilyString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- getFamilyWriter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getFanByte(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getFanByteReadable(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
for debugging
- getFanIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getFanOut() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getFavoredNode(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- getFavoredNode(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
repeated .ServerName favored_node = 1;
- getFavoredNode(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodesOrBuilder
-
repeated .ServerName favored_node = 1;
- getFavoredNodeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- getFavoredNodeBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- getFavoredNodeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- getFavoredNodeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
repeated .ServerName favored_node = 1;
- getFavoredNodeCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodesOrBuilder
-
repeated .ServerName favored_node = 1;
- getFavoredNodeList(String) - Static method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- getFavoredNodeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- getFavoredNodeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
repeated .ServerName favored_node = 1;
- getFavoredNodeList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodesOrBuilder
-
repeated .ServerName favored_node = 1;
- getFavoredNodeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- getFavoredNodeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
repeated .ServerName favored_node = 1;
- getFavoredNodeOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodesOrBuilder
-
repeated .ServerName favored_node = 1;
- getFavoredNodeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- getFavoredNodeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
repeated .ServerName favored_node = 1;
- getFavoredNodeOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodesOrBuilder
-
repeated .ServerName favored_node = 1;
- getFavoredNodes(List<ServerName>) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
-
- getFavoredNodes(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
-
- getFavoredNodes(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
-
- getFavoredNodes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfoOrBuilder
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesAsString(List<ServerName>) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
-
- getFavoredNodesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfoOrBuilder
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesForRegion(String) - Method in interface org.apache.hadoop.hbase.regionserver.FavoredNodesForRegion
-
Get the favored nodes mapping for this region.
- getFavoredNodesForRegion(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Return the favored nodes for a region given its encoded name.
- getFavoredNodesList(byte[]) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeAssignmentHelper
-
- getFavoredNodesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfoOrBuilder
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfoOrBuilder
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
-
repeated .ServerName favored_nodes = 3;
- getFavoredNodesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
repeated .ServerName favored_nodes = 2;
- getFavoredNodesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfoOrBuilder
-
repeated .ServerName favored_nodes = 2;
- getFavoredServerPosition(List<ServerName>, ServerName) - Static method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
-
Return the position of the server in the favoredNodes list.
- getFieldDesc(TMutation._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TAppend._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TAppend._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TAuthorization._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TCellVisibility._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
-
- getFieldName() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
-
- getFieldValue(AlreadyExists._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- getFieldValue(BatchMutation._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- getFieldValue(ColumnDescriptor._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getFieldValue(Hbase.append_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
- getFieldValue(Hbase.append_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- getFieldValue(Hbase.atomicIncrement_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- getFieldValue(Hbase.atomicIncrement_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- getFieldValue(Hbase.checkAndPut_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- getFieldValue(Hbase.checkAndPut_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- getFieldValue(Hbase.compact_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- getFieldValue(Hbase.compact_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- getFieldValue(Hbase.createTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- getFieldValue(Hbase.createTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- getFieldValue(Hbase.deleteAll_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- getFieldValue(Hbase.deleteAll_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- getFieldValue(Hbase.deleteAllRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- getFieldValue(Hbase.deleteAllRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- getFieldValue(Hbase.deleteAllRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- getFieldValue(Hbase.deleteAllRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- getFieldValue(Hbase.deleteAllTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- getFieldValue(Hbase.deleteAllTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- getFieldValue(Hbase.deleteTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- getFieldValue(Hbase.deleteTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- getFieldValue(Hbase.disableTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- getFieldValue(Hbase.disableTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- getFieldValue(Hbase.enableTable_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- getFieldValue(Hbase.enableTable_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- getFieldValue(Hbase.get_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- getFieldValue(Hbase.get_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- getFieldValue(Hbase.getColumnDescriptors_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- getFieldValue(Hbase.getColumnDescriptors_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- getFieldValue(Hbase.getRegionInfo_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- getFieldValue(Hbase.getRegionInfo_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- getFieldValue(Hbase.getRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- getFieldValue(Hbase.getRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- getFieldValue(Hbase.getRowOrBefore_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- getFieldValue(Hbase.getRowOrBefore_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- getFieldValue(Hbase.getRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- getFieldValue(Hbase.getRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- getFieldValue(Hbase.getRowsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- getFieldValue(Hbase.getRowsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- getFieldValue(Hbase.getRowsWithColumns_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- getFieldValue(Hbase.getRowsWithColumns_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- getFieldValue(Hbase.getRowsWithColumnsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getFieldValue(Hbase.getRowsWithColumnsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- getFieldValue(Hbase.getRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- getFieldValue(Hbase.getRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- getFieldValue(Hbase.getRowWithColumns_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- getFieldValue(Hbase.getRowWithColumns_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- getFieldValue(Hbase.getRowWithColumnsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- getFieldValue(Hbase.getRowWithColumnsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- getFieldValue(Hbase.getTableNames_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- getFieldValue(Hbase.getTableNames_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- getFieldValue(Hbase.getTableRegions_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- getFieldValue(Hbase.getTableRegions_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- getFieldValue(Hbase.getVer_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- getFieldValue(Hbase.getVer_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- getFieldValue(Hbase.getVerTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- getFieldValue(Hbase.getVerTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- getFieldValue(Hbase.increment_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- getFieldValue(Hbase.increment_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- getFieldValue(Hbase.incrementRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- getFieldValue(Hbase.incrementRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- getFieldValue(Hbase.isTableEnabled_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- getFieldValue(Hbase.isTableEnabled_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- getFieldValue(Hbase.majorCompact_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- getFieldValue(Hbase.majorCompact_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- getFieldValue(Hbase.mutateRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- getFieldValue(Hbase.mutateRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- getFieldValue(Hbase.mutateRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- getFieldValue(Hbase.mutateRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- getFieldValue(Hbase.mutateRowsTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- getFieldValue(Hbase.mutateRowsTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- getFieldValue(Hbase.mutateRowTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- getFieldValue(Hbase.mutateRowTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- getFieldValue(Hbase.scannerClose_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- getFieldValue(Hbase.scannerClose_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- getFieldValue(Hbase.scannerGet_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- getFieldValue(Hbase.scannerGet_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- getFieldValue(Hbase.scannerGetList_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- getFieldValue(Hbase.scannerGetList_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- getFieldValue(Hbase.scannerOpen_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- getFieldValue(Hbase.scannerOpen_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- getFieldValue(Hbase.scannerOpenTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- getFieldValue(Hbase.scannerOpenTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- getFieldValue(Hbase.scannerOpenWithPrefix_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- getFieldValue(Hbase.scannerOpenWithPrefix_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- getFieldValue(Hbase.scannerOpenWithScan_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- getFieldValue(Hbase.scannerOpenWithScan_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- getFieldValue(Hbase.scannerOpenWithStop_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- getFieldValue(Hbase.scannerOpenWithStop_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- getFieldValue(Hbase.scannerOpenWithStopTs_args._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- getFieldValue(Hbase.scannerOpenWithStopTs_result._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- getFieldValue(IllegalArgument._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- getFieldValue(IOError._Fields) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- getFieldValue(Mutation._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- getFieldValue(TAppend._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- getFieldValue(TCell._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- getFieldValue(TColumn._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- getFieldValue(TIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- getFieldValue(TRegionInfo._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getFieldValue(TRowResult._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getFieldValue(TScan._Fields) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getFieldValue(TAppend._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- getFieldValue(TAuthorization._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- getFieldValue(TCellVisibility._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
-
- getFieldValue(TColumn._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- getFieldValue(TColumnIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- getFieldValue(TColumnValue._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- getFieldValue(TDelete._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getFieldValue(TGet._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getFieldValue(THBaseService.append_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
- getFieldValue(THBaseService.append_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- getFieldValue(THBaseService.checkAndDelete_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- getFieldValue(THBaseService.checkAndDelete_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- getFieldValue(THBaseService.checkAndPut_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- getFieldValue(THBaseService.checkAndPut_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- getFieldValue(THBaseService.closeScanner_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- getFieldValue(THBaseService.closeScanner_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- getFieldValue(THBaseService.deleteMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- getFieldValue(THBaseService.deleteMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- getFieldValue(THBaseService.deleteSingle_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- getFieldValue(THBaseService.deleteSingle_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- getFieldValue(THBaseService.exists_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- getFieldValue(THBaseService.exists_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- getFieldValue(THBaseService.get_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- getFieldValue(THBaseService.get_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- getFieldValue(THBaseService.getMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- getFieldValue(THBaseService.getMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- getFieldValue(THBaseService.getScannerResults_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- getFieldValue(THBaseService.getScannerResults_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- getFieldValue(THBaseService.getScannerRows_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- getFieldValue(THBaseService.getScannerRows_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- getFieldValue(THBaseService.increment_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- getFieldValue(THBaseService.increment_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- getFieldValue(THBaseService.mutateRow_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- getFieldValue(THBaseService.mutateRow_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- getFieldValue(THBaseService.openScanner_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- getFieldValue(THBaseService.openScanner_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- getFieldValue(THBaseService.put_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- getFieldValue(THBaseService.put_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- getFieldValue(THBaseService.putMultiple_args._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- getFieldValue(THBaseService.putMultiple_result._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- getFieldValue(TIllegalArgument._Fields) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- getFieldValue(TIncrement._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getFieldValue(TIOError._Fields) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- getFieldValue(TPut._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getFieldValue(TResult._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- getFieldValue(TRowMutations._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- getFieldValue(TScan._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getFieldValue(TTimeRange._Fields) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- getFileCacheForTesting() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
Exposed for Testing!
- getFileContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Return the file context of the HFile this reader belongs to
- getFileContext() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Return the file context for the HFile this writer belongs to
- getFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- getFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- getFileCreateTime() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- getFileDetails(Collection<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
Extracts some details about the files to compact that are commonly needed by compactors.
- getFileInfo() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getFileInfoOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getFileInfoOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 file_info_offset = 1;
- getFileInfoOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 file_info_offset = 1;
- getFileInfoOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 file_info_offset = 1;
- getFileLinkWithPreNSPath(Path) - Method in class org.apache.hadoop.hbase.util.HFileV1Detector
-
Creates a FileLink which adds pre-namespace paths in its list of available paths.
- getFileList(Configuration, List<Path>, PathFilter) - Static method in class org.apache.hadoop.hbase.master.SplitLogManager
-
Get a list of paths that need to be split given a set of server-specific directories and
optionally a filter.
- getFilename() - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- getFilename() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string file_name = 3;
- getFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
optional string file_name = 3;
- getFileName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
optional string file_name = 3;
- getFileName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- getFileNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string file_name = 3;
- getFileNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
optional string file_name = 3;
- getFileNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
optional string file_name = 3;
- getFileNumFromFileName(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
A log file has a creation timestamp (in ms) in its file name (
FSHLog.filenum
.
- getFilePermissions(FileSystem, Configuration, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Get the file permissions specified in the configuration, if they are
enabled.
- getFileRegion() - Method in class org.apache.hadoop.hbase.io.Reference
-
- getFiles() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- getFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
Get the backing files associated with this WAL.
- getFilesForScanOrGet(boolean, byte[], byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets the store files to scan for a Scan or Get request.
- getFilesForScanOrGet(boolean, byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getFileSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
optional uint64 file_size = 3;
- getFileSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
optional uint64 file_size = 3;
- getFileSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFileOrBuilder
-
optional uint64 file_size = 3;
- getFileStatus(FileSystem) - Method in class org.apache.hadoop.hbase.io.FileLink
-
Get the FileStatus of the referenced file.
- getFileStatus() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- getFilesystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFileSystem() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getFileSystem() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getFilesystem() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getFileSystem() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
- getFilter() - Method in class org.apache.hadoop.hbase.client.Query
-
- getFilter() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getFilter() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- getFilter() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .Filter filter = 4;
- getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional .Filter filter = 4;
- getFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional .Filter filter = 4;
- getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .Filter filter = 5;
- getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional .Filter filter = 5;
- getFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional .Filter filter = 5;
- getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
required .Filter filter = 1;
- getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
required .Filter filter = 1;
- getFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapperOrBuilder
-
required .Filter filter = 1;
- getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
required .Filter filter = 1;
- getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
required .Filter filter = 1;
- getFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilterOrBuilder
-
required .Filter filter = 1;
- getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
required .Filter filter = 1;
- getFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
required .Filter filter = 1;
- getFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilterOrBuilder
-
required .Filter filter = 1;
- getFilter() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional string filter = 8;
- getFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional string filter = 8;
- getFilter() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional string filter = 8;
- getFilter() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getFilter() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFilter() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getFilter__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getFilter__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFilter__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getFilterArguments(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns the arguments of the filter from the filter string
- getFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .Filter filter = 4;
- getFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .Filter filter = 5;
- getFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
required .Filter filter = 1;
- getFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
required .Filter filter = 1;
- getFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
required .Filter filter = 1;
- getFilterBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional string filter = 8;
- getFilterBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional string filter = 8;
- getFilterBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional string filter = 8;
- getFilterEntries() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getFilterEntries() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
The number of Bloom filter entries in this store file, or an estimate
thereof, if the Bloom filter is not loaded.
- getFilterIfMissing() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Get whether entire row should be filtered if column is not found.
- getFilterIfMissing() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bool filter_if_missing = 5;
- getFilterIfMissing() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
optional bool filter_if_missing = 5;
- getFilterIfMissing() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
optional bool filter_if_missing = 5;
- getFilterName(byte[]) - Static method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns the filter name given a simple filter expression
- getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .Filter filter = 4;
- getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional .Filter filter = 4;
- getFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional .Filter filter = 4;
- getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .Filter filter = 5;
- getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional .Filter filter = 5;
- getFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional .Filter filter = 5;
- getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
required .Filter filter = 1;
- getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
required .Filter filter = 1;
- getFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapperOrBuilder
-
required .Filter filter = 1;
- getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
required .Filter filter = 1;
- getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
required .Filter filter = 1;
- getFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilterOrBuilder
-
required .Filter filter = 1;
- getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
required .Filter filter = 1;
- getFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
required .Filter filter = 1;
- getFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilterOrBuilder
-
required .Filter filter = 1;
- getFilterParams(Configuration, String) - Static method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
Constructs a mapping of configuration properties to be used for filter
initialization.
- getFilters() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Get the filters.
- getFilters(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- getFilters(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
repeated .Filter filters = 2;
- getFilters(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
-
repeated .Filter filters = 2;
- getFiltersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- getFiltersBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- getFiltersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- getFiltersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
repeated .Filter filters = 2;
- getFiltersCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
-
repeated .Filter filters = 2;
- getFiltersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- getFiltersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
repeated .Filter filters = 2;
- getFiltersList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
-
repeated .Filter filters = 2;
- getFiltersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- getFiltersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
repeated .Filter filters = 2;
- getFiltersOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
-
repeated .Filter filters = 2;
- getFiltersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- getFiltersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
repeated .Filter filters = 2;
- getFiltersOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
-
repeated .Filter filters = 2;
- getFilterString() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getFilterString() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Get
-
Compile the table and column family (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Compile the column family (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Operation
-
Produces a Map containing a fingerprint which identifies the type and
the static schema components of a query (i.e.
- getFingerprint() - Method in class org.apache.hadoop.hbase.client.Scan
-
Compile the table and column family (i.e.
- getFirst() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
required bytes first = 1;
- getFirst() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
required bytes first = 1;
- getFirst() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPairOrBuilder
-
required bytes first = 1;
- getFirst(long[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
-
- getFirst(Collection<T>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
-
first/last
- getFirst() - Method in class org.apache.hadoop.hbase.util.Pair
-
Return the first element stored in the pair.
- getFirst() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
Return the first element stored in the pair.
- getFirst() - Method in class org.apache.hadoop.hbase.util.Triple
-
- getFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 first_data_block_offset = 9;
- getFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 first_data_block_offset = 9;
- getFirstDataBlockOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 first_data_block_offset = 9;
- getFirstFailureAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
- getFirstInsertionIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getFirstKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getFirstKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
-
- getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.CopyKeyDataBlockEncoder
-
- getFirstKeyInBlock(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Return first key in block.
- getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.FastDiffDeltaEncoder
-
- getFirstKeyInBlock(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.encoding.PrefixKeyDeltaEncoder
-
- getFirstKeyInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- getFirstKeyInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getFirstKeyInBlock(HFileBlock) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getFirstPart(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
repeated bytes first_part = 1;
- getFirstPart(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
repeated bytes first_part = 1;
- getFirstPart(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponseOrBuilder
-
repeated bytes first_part = 1;
- getFirstPartCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
repeated bytes first_part = 1;
- getFirstPartCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
repeated bytes first_part = 1;
- getFirstPartCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponseOrBuilder
-
repeated bytes first_part = 1;
- getFirstPartList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
repeated bytes first_part = 1;
- getFirstPartList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
repeated bytes first_part = 1;
- getFirstPartList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponseOrBuilder
-
repeated bytes first_part = 1;
- getFirstRowKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
TODO left from
HFile
version 1: move this to StoreFile after Ryan's
patch goes in to eliminate
KeyValue
here.
- getFirstRowKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getFlushableSize() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- getFlushableSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFlushableSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
On flush, how much memory we will clear.
- getFlushableSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getFlushDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- getFlushed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
optional bool flushed = 2;
- getFlushed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
optional bool flushed = 2;
- getFlushed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
-
optional bool flushed = 2;
- getFlushedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFlushedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of cells flushed to disk.
- getFlushedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getFlushedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getFlushedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total amount of data flushed to disk, in bytes.
- getFlushedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getFlushOutput(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
repeated string flush_output = 3;
- getFlushOutput(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
repeated string flush_output = 3;
- getFlushOutput(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptorOrBuilder
-
repeated string flush_output = 3;
- getFlushOutputBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
repeated string flush_output = 3;
- getFlushOutputBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
repeated string flush_output = 3;
- getFlushOutputBytes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptorOrBuilder
-
repeated string flush_output = 3;
- getFlushOutputCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
repeated string flush_output = 3;
- getFlushOutputCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
repeated string flush_output = 3;
- getFlushOutputCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptorOrBuilder
-
repeated string flush_output = 3;
- getFlushOutputList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
repeated string flush_output = 3;
- getFlushOutputList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
repeated string flush_output = 3;
- getFlushOutputList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptorOrBuilder
-
repeated string flush_output = 3;
- getFlushPolicyClass(HTableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
-
Get FlushPolicy class for the given table.
- getFlushPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
This gets the class associated with the flush policy which determines the stores need to be
flushed when flushing a region.
- getFlushQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the flush queue.
- getFlushRequester() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getFlushRequester() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getFlushSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
optional uint64 flush_sequence_number = 4;
- getFlushSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
optional uint64 flush_sequence_number = 4;
- getFlushSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
optional uint64 flush_sequence_number = 4;
- getFollowingKvCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint32 following_kv_count = 7;
- getFollowingKvCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
optional uint32 following_kv_count = 7;
- getFollowingKvCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
optional uint32 following_kv_count = 7;
- getForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
optional bool force = 2 [default = false];
- getForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
optional bool force = 2 [default = false];
- getForce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequestOrBuilder
-
optional bool force = 2 [default = false];
- getForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
optional bool forcible = 3 [default = false];
- getForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
optional bool forcible = 3 [default = false];
- getForcible() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
-
optional bool forcible = 3 [default = false];
- getForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
optional bool forcible = 3 [default = false];
- getForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
optional bool forcible = 3 [default = false];
- getForcible() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequestOrBuilder
-
optional bool forcible = 3 [default = false];
- getForeignExceptionMessage() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getFormat() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getFormat() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFormat() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getFormat__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getFormat__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFormat__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getFormatVersion(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
- getFrags() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFrags__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getFreeBytes() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- getFreeMemory() - Method in class org.apache.hadoop.hbase.util.JVM
-
- getFreeSize() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the free size of the block cache, in bytes.
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- getFreeSize() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getFrom() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
optional uint64 from = 1;
- getFrom() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
optional uint64 from = 1;
- getFrom() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRangeOrBuilder
-
optional uint64 from = 1;
- getFromOnlineRegions(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getFromOnlineRegions(String) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
- getFromThrift(TGet) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Creates a
Get
(HBase) from a
TGet
(Thrift).
- getFs() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the handle on the local file system
- getFsToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required .DelegationToken fs_token = 3;
- getFsToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
required .DelegationToken fs_token = 3;
- getFsToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
required .DelegationToken fs_token = 3;
- getFsTokenBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required .DelegationToken fs_token = 3;
- getFsTokenOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required .DelegationToken fs_token = 3;
- getFsTokenOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
required .DelegationToken fs_token = 3;
- getFsTokenOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
required .DelegationToken fs_token = 3;
- getFuzzyKeysData(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysData(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysData(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilterOrBuilder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilterOrBuilder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilterOrBuilder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilterOrBuilder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getFuzzyKeysDataOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilterOrBuilder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- getGeneralBloomFilterMetadata() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Retrieves general Bloom filter metadata as appropriate for each
HFile
version.
- getGeneralBloomFilterMetadata() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
Returns a buffer with the Bloom filter metadata.
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getGeneralQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the general queue for metrics.
- getGeneralQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional .GenericExceptionMessage generic_exception = 2;
- getGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
optional .GenericExceptionMessage generic_exception = 2;
- getGenericException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
-
optional .GenericExceptionMessage generic_exception = 2;
- getGenericExceptionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional .GenericExceptionMessage generic_exception = 2;
- getGenericExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional .GenericExceptionMessage generic_exception = 2;
- getGenericExceptionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
optional .GenericExceptionMessage generic_exception = 2;
- getGenericExceptionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
-
optional .GenericExceptionMessage generic_exception = 2;
- getGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .Get get = 3;
- getGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
optional .Get get = 3;
- getGet() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
-
optional .Get get = 3;
- getGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .Get get = 2;
- getGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
required .Get get = 2;
- getGet() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
-
required .Get get = 2;
- getGet() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
the TGet to check for
- getGet() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
the TGet to fetch
- getGetBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .Get get = 3;
- getGetBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .Get get = 2;
- getGetOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .Get get = 3;
- getGetOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
optional .Get get = 3;
- getGetOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
-
optional .Get get = 3;
- getGetOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .Get get = 2;
- getGetOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
required .Get get = 2;
- getGetOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
-
required .Get get = 2;
- getGets() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
a list of TGets to fetch, the Result list
will have the Results at corresponding positions
or null if there was an error
- getGetsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- getGetsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- getGlobalLimiter() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
Return the limiter associated with this quota.
- getGlobalMemStoreLowerMark(Configuration, float) - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
-
Retrieve configured size for global memstore lower water mark as percentage of total heap.
- getGlobalMemStorePercent(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
-
Retrieve global memstore configured size as percentage of total heap.
- getGlobalMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- getGlobalPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .GlobalPermission global_permission = 2;
- getGlobalPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
optional .GlobalPermission global_permission = 2;
- getGlobalPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
-
optional .GlobalPermission global_permission = 2;
- getGlobalPermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .GlobalPermission global_permission = 2;
- getGlobalPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .GlobalPermission global_permission = 2;
- getGlobalPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
optional .GlobalPermission global_permission = 2;
- getGlobalPermissionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
-
optional .GlobalPermission global_permission = 2;
- getGlobalSource() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactory
-
- getGlobalSource() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl
-
- getGroupAuths(String[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getGroupAuths(String[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getGroupAuths(String[], boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Retrieve the visibility labels for the groups.
- getGroupAuthsAsOrdinals(String[]) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
Returns the list of ordinals of labels associated with the groups
- getGroupName(String) - Static method in class org.apache.hadoop.hbase.AuthUtil
-
Returns the actual name for a group principal (stripped of the
group prefix).
- getGroupNames() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the list of groups of which this user is a member.
- getHasCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional bool has_compression = 1;
- getHasCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
optional bool has_compression = 1;
- getHasCompression() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
-
optional bool has_compression = 1;
- getHash() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
optional bytes hash = 5;
- getHash() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
optional bytes hash = 5;
- getHash() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
-
optional bytes hash = 5;
- getHashCount() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getHashType() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getHashType(Configuration) - Static method in class org.apache.hadoop.hbase.util.Hash
-
This utility method converts the name of the configured
hash type to a symbolic constant.
- getHasTagCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional bool has_tag_compression = 3;
- getHasTagCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
optional bool has_tag_compression = 3;
- getHasTagCompression() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
-
optional bool has_tag_compression = 3;
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getHBaseVersion() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getHBaseVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getHbaseVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .HBaseVersionFileContent hbase_version = 1;
- getHbaseVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
optional .HBaseVersionFileContent hbase_version = 1;
- getHbaseVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
optional .HBaseVersionFileContent hbase_version = 1;
- getHbaseVersionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .HBaseVersionFileContent hbase_version = 1;
- getHbaseVersionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .HBaseVersionFileContent hbase_version = 1;
- getHbaseVersionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
optional .HBaseVersionFileContent hbase_version = 1;
- getHbaseVersionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
optional .HBaseVersionFileContent hbase_version = 1;
- getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getHDFSBlockDistribution() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getHDFSBlocksDistribution() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getHDFSBlocksDistribution() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getHead() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- getHeader() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getHeader() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
- getHeader(String) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getHeader(String) - Method in interface org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.HttpInteraction
-
Returns the value of a header.
- getHeaders() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getHeadPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the head of the linked list (least recently used).
- getHeap() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- getHeapMemoryManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getHeapMemoryManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getHeapOccupancy() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
optional int32 heapOccupancy = 2 [default = 0];
- getHeapOccupancy() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
optional int32 heapOccupancy = 2 [default = 0];
- getHeapOccupancy() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStatsOrBuilder
-
optional int32 heapOccupancy = 2 [default = 0];
- getHeapOccupancyPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- getHeapOccupancyPercent() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- getHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int32 heapSizeMB = 4;
- getHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
optional int32 heapSizeMB = 4;
- getHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
optional int32 heapSizeMB = 4;
- getHeartbeatMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool heartbeat_message = 9;
- getHeartbeatMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
optional bool heartbeat_message = 9;
- getHeartbeatMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
optional bool heartbeat_message = 9;
- getHfile() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string hfile = 3;
- getHfile() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
optional string hfile = 3;
- getHfile() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
-
optional string hfile = 3;
- getHFileBlock() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
-
- getHfileBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string hfile = 3;
- getHfileBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
optional string hfile = 3;
- getHfileBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
-
optional string hfile = 3;
- getHFileCleaner() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getHFileContext() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockDecodingContext
-
- getHFileContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
-
- getHFileContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- getHFileContext() - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
- getHFileContext() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getHFilecorruptionChecker() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getHFileFromBackReference(Path, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the full path of the HFile referenced by the back reference
- getHFileFromBackReference(Configuration, Path) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the full path of the HFile referenced by the back reference
- getHFileMinorVersion() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getHfileName() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- getHFileNames(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Returns the store file names in the snapshot.
- getHFileReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getHFilesChecked() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getHFileVersion() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getHfs() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- getHistogram(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- getHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
-
- getHitCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getHitCachingRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitCachingRatioPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getHitCount() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the number of hits to the map.
- getHitRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHitRatio() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the hit ratio.
- getHitRatioPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getHost() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
- getHostAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- getHostAndPort() - Method in class org.apache.hadoop.hbase.ServerName
-
- getHostAndWeights() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
- getHostInetAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- getHostname() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getHostname() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getHostname() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- getHostName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
required string host_name = 1;
- getHostName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
required string host_name = 1;
- getHostName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
-
required string host_name = 1;
- getHostname() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string hostname = 3;
- getHostname() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional string hostname = 3;
- getHostname() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional string hostname = 3;
- getHostname(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getHostname() - Method in class org.apache.hadoop.hbase.ServerName
-
- getHostNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
required string host_name = 1;
- getHostNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
required string host_name = 1;
- getHostNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
-
required string host_name = 1;
- getHostnameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string hostname = 3;
- getHostnameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional string hostname = 3;
- getHostnameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional string hostname = 3;
- getHostnamePort(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getHostnamePort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getHRegion() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
- getHRegionInfo(Result, byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
-
- getHRegionInfo() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
-
- getHRegionInfo() - Method in interface org.apache.hadoop.hbase.master.handler.TotesHRegionInfo
-
- getHRegionInfo(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns HRegionInfo object from the column
HConstants.CATALOG_FAMILY:HConstants.REGIONINFO_QUALIFIER of the catalog
table Result.
- getHRegionInfoAndServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
- getHris() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getHTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- getHTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- getHTableDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getHTableDescriptor(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getHTableDescriptorArray(MasterProtos.GetTableDescriptorsResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Get HTableDescriptor[] from GetTableDescriptorsResponse protobuf
- getHTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getHTableDescriptorsByTableName(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getHTableMultiplexerStatus() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- getHttpClient() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- getIa() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
if the scannerId is invalid
- getIa() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
if the scannerId is invalid
- getId() - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
This method allows you to retrieve the identifier for the operation if one
was set.
- getId() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getId() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- getId() - Method in enum org.apache.hadoop.hbase.io.hfile.BlockType
-
- getId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
required int32 id = 1;
- getId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
required int32 id = 1;
- getId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
-
required int32 id = 1;
- getId() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getId() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the identifier of this peer
- getId() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
Get the identifier of this peer
- getId() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- getId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional int64 id = 4;
- getId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
optional int64 id = 4;
- getId() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
optional int64 id = 4;
- getID() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- getId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
id of a scanner returned by scannerOpen
- getId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
id of a scanner returned by scannerOpen
- getId() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
id of a scanner returned by scannerOpen
- getId() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
- getIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
optional bytes identifier = 1;
- getIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
optional bytes identifier = 1;
- getIdentifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
-
optional bytes identifier = 1;
- getIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional bytes identifier = 1;
- getIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
optional bytes identifier = 1;
- getIdentifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
-
optional bytes identifier = 1;
- getIdentifier(String, SecretManager<T>) - Static method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- getIdentifier() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- getIdentifier() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getIfCached(Path) - Static method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- getIfOlderThanTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
optional uint64 if_older_than_ts = 2;
- getIfOlderThanTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
optional uint64 if_older_than_ts = 2;
- getIfOlderThanTs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
-
optional uint64 if_older_than_ts = 2;
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- getImplData() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- getIncludesMvccVersionByte() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional bool include_sys_tables = 3 [default = false];
- getIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
optional bool include_sys_tables = 3 [default = false];
- getIncludeSysTables() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
optional bool include_sys_tables = 3 [default = false];
- getIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional bool include_sys_tables = 2 [default = false];
- getIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
optional bool include_sys_tables = 2 [default = false];
- getIncludeSysTables() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequestOrBuilder
-
optional bool include_sys_tables = 2 [default = false];
- getIncrement() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
The single increment to apply
- getIncrement() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
the TIncrement to increment
- getIncrements() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
The list of increments
- getIncrementsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- getIncrementsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- getIndex(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
- getIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional uint32 index = 1;
- getIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
optional uint32 index = 1;
- getIndex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
-
optional uint32 index = 1;
- getIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional uint32 index = 1;
- getIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional uint32 index = 1;
- getIndex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional uint32 index = 1;
- getInfo(String) - Static method in class org.apache.hadoop.hbase.security.SecurityInfo
-
Returns the security configuration associated with the given service name.
- getInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
optional int32 infoPort = 1;
- getInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
optional int32 infoPort = 1;
- getInfoPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfoOrBuilder
-
optional int32 infoPort = 1;
- getInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
optional uint32 info_port = 3;
- getInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
optional uint32 info_port = 3;
- getInfoPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
-
optional uint32 info_port = 3;
- getInformativeName() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Event implementations should override thie class to provide an
informative name about what event they are handling.
- getInformativeName() - Method in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- getInfoServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getInfoServerPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint32 info_server_port = 9;
- getInfoServerPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint32 info_server_port = 9;
- getInfoServerPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint32 info_server_port = 9;
- getInfoServerPort() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getInitialCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getInitialDelay() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getInitialState() - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Return the initial state object that will be used for the first call to executeFromState().
- getInlineBlockType() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- getInlineBlockType() - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
The type of blocks this block writer produces.
- getInlineBlockType() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- getInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional bool inMemory = 4;
- getInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
optional bool inMemory = 4;
- getInMemory() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
optional bool inMemory = 4;
- getInputStream() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- getInputStream() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
-
- getInputStream(InputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Get a SASL wrapped InputStream.
- getInstance(String) - Static method in class org.apache.hadoop.hbase.ChoreService
-
- getInstance(Class<T>) - Static method in class org.apache.hadoop.hbase.CompatibilityFactory
-
- getInstance(Class<T>) - Static method in class org.apache.hadoop.hbase.CompatibilitySingletonFactory
-
Get the singleton instance of Any classes defined by compatibiliy jar's
- getInstance() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getInstance() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getInstance() - Static method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getInstance() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
optional string instance = 2;
- getInstance() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
optional string instance = 2;
- getInstance() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
optional string instance = 2;
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
- getInstance(int, int) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
- getInstance() - Static method in class org.apache.hadoop.hbase.regionserver.NoLimitScannerContext
-
- getInstance() - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- getInstance(Configuration, UserProvider) - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- getInstance() - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.trace.SpanReceiverHost
-
- getInstance(FileSystem, Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getInstance(int) - Static method in class org.apache.hadoop.hbase.util.Hash
-
Get a singleton instance of hash function of a given type.
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.util.Hash
-
Get a singleton instance of hash function of a type
defined in the configuration.
- getInstance() - Static method in class org.apache.hadoop.hbase.util.JenkinsHash
-
- getInstance() - Static method in class org.apache.hadoop.hbase.util.MurmurHash
-
- getInstance() - Static method in class org.apache.hadoop.hbase.util.MurmurHash3
-
- getInstance(Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getInstanceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
optional string instance = 2;
- getInstanceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
optional string instance = 2;
- getInstanceBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
optional string instance = 2;
- getInt(Configuration, String, String, int) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Get the value of the name
property as an int
, possibly
referring to the deprecated name of the configuration property.
- getInt(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getInt() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getInt(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the int value at index
- getInt() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next int value from this range.
- getInt(byte[]) - Static method in class org.apache.hadoop.hbase.util.vint.UVIntTool
-
bytes -> int
- getInt(byte[], int) - Static method in class org.apache.hadoop.hbase.util.vint.UVIntTool
-
- getInt(InputStream) - Static method in class org.apache.hadoop.hbase.util.vint.UVIntTool
-
- getInterpreterClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required string interpreter_class_name = 1;
- getInterpreterClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
required string interpreter_class_name = 1;
- getInterpreterClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequestOrBuilder
-
required string interpreter_class_name = 1;
- getInterpreterClassNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required string interpreter_class_name = 1;
- getInterpreterClassNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
required string interpreter_class_name = 1;
- getInterpreterClassNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequestOrBuilder
-
required string interpreter_class_name = 1;
- getInterpreterSpecificBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
optional bytes interpreter_specific_bytes = 3;
- getInterpreterSpecificBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
optional bytes interpreter_specific_bytes = 3;
- getInterpreterSpecificBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequestOrBuilder
-
optional bytes interpreter_specific_bytes = 3;
- getInterval() - Method in class org.apache.hadoop.metrics2.lib.MetricMutableQuantiles
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- getIo() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- getIoEngine() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getIOHitsPerSecond() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- getIOTimePerHit() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
-
- getIp4Address() - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- getIp6Address() - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- getIpAddress() - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- getIsActiveMaster() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Whether this master is the active master
- getIsActiveMaster() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getIsMasterRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
-
required bool is_master_running = 1;
- getIsMasterRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
required bool is_master_running = 1;
- getIsMasterRunning() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponseOrBuilder
-
required bool is_master_running = 1;
- getIsolationLevel() - Method in class org.apache.hadoop.hbase.client.Query
-
- getIsProcedureAborted() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
-
required bool is_procedure_aborted = 1;
- getIsProcedureAborted() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
required bool is_procedure_aborted = 1;
- getIsProcedureAborted() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponseOrBuilder
-
required bool is_procedure_aborted = 1;
- getIsRecovering() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
optional bool isRecovering = 3;
- getIsRecovering() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
optional bool isRecovering = 3;
- getIsRecovering() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
-
optional bool isRecovering = 3;
- getIsShared() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional bool is_shared = 4;
- getIsShared() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional bool is_shared = 4;
- getIsShared() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional bool is_shared = 4;
- getIssueDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
optional int64 issue_date = 4;
- getIssueDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
optional int64 issue_date = 4;
- getIssueDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
-
optional int64 issue_date = 4;
- getIssueDate() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getItemAllocationSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- getIterator(int) - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Provides access to compressed value.
- getIterator() - Method in class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
-
- getIv() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- getIv() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the initialization vector
- getIv() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
optional bytes iv = 4;
- getIv() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
optional bytes iv = 4;
- getIv() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
-
optional bytes iv = 4;
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- getIvLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the expected initialization vector length, in bytes, or 0 if not applicable
- getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Get the expected length for the initialization vector
- getIvLength() - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Get the expected length for the initialization vector
- getJar(Class) - Static method in class org.apache.hadoop.hbase.mapreduce.JarFinder
-
Returns the full path to the Jar containing the class.
- GetJavaProperty - Class in org.apache.hadoop.hbase.util
-
A generic way for querying Java properties.
- GetJavaProperty() - Constructor for class org.apache.hadoop.hbase.util.GetJavaProperty
-
- getJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string jerseyVersion = 5;
- getJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string jerseyVersion = 5;
- getJerseyVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string jerseyVersion = 5;
- getJerseyVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string jerseyVersion = 5;
- getJerseyVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string jerseyVersion = 5;
- getJerseyVersionBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string jerseyVersion = 5;
- getJournal() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
Get the journal for the transaction.
- getJournal() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- getJournal() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
-
Get the journal for the transaction.
- getJournal() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- getJVMVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string jvmVersion = 2;
- getJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string jvmVersion = 2;
- getJvmVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string jvmVersion = 2;
- getJvmVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string jvmVersion = 2;
- getJvmVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string jvmVersion = 2;
- getJvmVersionBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string jvmVersion = 2;
- getKeepAliveMasterService() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Deprecated.
- getKeepAliveMasterService() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getKeepDeletedCells() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getKey() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKey(String) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Retrieve the key for a given key aliase
- getKey(String) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Gets a buffer view to the current key.
- getKey() - Method in class org.apache.hadoop.hbase.KeyValue
-
Do not use unless you have to.
- getKey() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
required .WALKey key = 1;
- getKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
required .WALKey key = 1;
- getKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
-
required .WALKey key = 1;
- getKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
required bytes key = 3;
- getKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
required bytes key = 3;
- getKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
-
required bytes key = 3;
- getKey() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Get the key of this entry.
- getKey() - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- getKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
required bytes key = 1;
- getKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
required bytes key = 1;
- getKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
required bytes key = 1;
- getKey() - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
-
Gets the key
- getKeyBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
required .WALKey key = 1;
- getKeyBytes() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKeyBytesHash() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKeyCount() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
- getKeyCount() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getKeyCount() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- getKeyDataStructureSize(int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Computes the number of bytes that a KeyValue
instance with the provided
characteristics would take up in its underlying data structure for the key.
- getKeyDeepCopy() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
- getKeyDeepCopy() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Does a deep copy of the key at the current position.
- getKeyFormat() - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- getKeyForNextColumn(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- getKeyForNextRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- getKeyId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
required int32 key_id = 3;
- getKeyId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
required int32 key_id = 3;
- getKeyId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
-
required int32 key_id = 3;
- getKeyId() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- getKeyId() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the key length required by this cipher, in bytes
- getKeyLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getKeyLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getKeyOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getKeyOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getKeyOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
required .WALKey key = 1;
- getKeyOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
required .WALKey key = 1;
- getKeyOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
-
required .WALKey key = 1;
- getKeyProvider(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
- getKeys(String[]) - Method in interface org.apache.hadoop.hbase.io.crypto.KeyProvider
-
Retrieve keys for a given set of key aliases
- getKeys(String[]) - Method in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- getKeyString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getKeyString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getKeyString() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Convenience method to get a copy of the key as a string - interpreting the
bytes as UTF8.
- getKeyString() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getKeyType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional .CellType key_type = 5;
- getKeyType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
optional .CellType key_type = 5;
- getKeyType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
optional .CellType key_type = 5;
- getKeyValue() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
currently must do deep copy into new array
- getKeyValue() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
- getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getKeyValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
-
- getKeyValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- getKeyValueBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
repeated bytes key_value_bytes = 2;
- getKeyValueBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
repeated bytes key_value_bytes = 2;
- getKeyValueBytes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
-
repeated bytes key_value_bytes = 2;
- getKeyValueBytesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
repeated bytes key_value_bytes = 2;
- getKeyValueBytesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
repeated bytes key_value_bytes = 2;
- getKeyValueBytesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
-
repeated bytes key_value_bytes = 2;
- getKeyValueBytesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
repeated bytes key_value_bytes = 2;
- getKeyValueBytesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
repeated bytes key_value_bytes = 2;
- getKeyValueBytesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
-
repeated bytes key_value_bytes = 2;
- getKeyValueCount(RpcController, ExampleProtos.CountRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.BlockingInterface
-
- getKeyValueCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
-
rpc getKeyValueCount(.CountRequest) returns (.CountResponse);
- getKeyValueCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.Interface
-
rpc getKeyValueCount(.CountRequest) returns (.CountResponse);
- getKeyValueCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.Stub
-
- getKeyValueCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
-
Returns a count of all KeyValues in the region where this coprocessor is loaded.
- getKeyValueDataStructureSize(int, int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Computes the number of bytes that a KeyValue
instance with the provided
characteristics would take up for its underlying data structure.
- getKeyValueDataStructureSize(int, int, int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Computes the number of bytes that a KeyValue
instance with the provided
characteristics would take up for its underlying data structure.
- getKeyValueDataStructureSize(int, int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
-
Computes the number of bytes that a KeyValue
instance with the provided
characteristics would take up for its underlying data structure.
- getKeyValueString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
Need this separate method so we can call it from subclasses' toString() methods
- getKeyValueTypeWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
methods
- getKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
required .TokenIdentifier.Kind kind = 1;
- getKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
required .TokenIdentifier.Kind kind = 1;
- getKind() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
-
required .TokenIdentifier.Kind kind = 1;
- getKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional string kind = 3;
- getKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
optional string kind = 3;
- getKind() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
-
optional string kind = 3;
- getKind() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getKindBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional string kind = 3;
- getKindBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
optional string kind = 3;
- getKindBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
-
optional string kind = 3;
- getL2BlockCacheHeapPercent(Configuration) - Static method in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
-
- getLabel(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
repeated string label = 1;
- getLabel(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
repeated string label = 1;
- getLabel(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.AuthorizationsOrBuilder
-
repeated string label = 1;
- getLabel(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
repeated bytes label = 1;
- getLabel(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
repeated bytes label = 1;
- getLabel(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponseOrBuilder
-
repeated bytes label = 1;
- getLabel() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
required bytes label = 1;
- getLabel() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
required bytes label = 1;
- getLabel() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelOrBuilder
-
required bytes label = 1;
- getLabel(int) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelOrdinalProvider
-
Returns the string associated with the ordinal.
- getLabel(int) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getLabelBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
repeated string label = 1;
- getLabelBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
repeated string label = 1;
- getLabelBytes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.AuthorizationsOrBuilder
-
repeated string label = 1;
- getLabelCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
repeated string label = 1;
- getLabelCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
repeated string label = 1;
- getLabelCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.AuthorizationsOrBuilder
-
repeated string label = 1;
- getLabelCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
repeated bytes label = 1;
- getLabelCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
repeated bytes label = 1;
- getLabelCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponseOrBuilder
-
repeated bytes label = 1;
- getLabelList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
repeated string label = 1;
- getLabelList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
repeated string label = 1;
- getLabelList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.AuthorizationsOrBuilder
-
repeated string label = 1;
- getLabelList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
repeated bytes label = 1;
- getLabelList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
repeated bytes label = 1;
- getLabelList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponseOrBuilder
-
repeated bytes label = 1;
- getLabelOrdinal(String) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelOrdinalProvider
-
- getLabelOrdinal(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getLabels() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getLabels(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated string labels = 10;
- getLabels(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
repeated string labels = 10;
- getLabels(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
repeated string labels = 10;
- getLabels() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getLabels() - Method in class org.apache.hadoop.hbase.security.visibility.Authorizations
-
- getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
-
- getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
-
- getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
-
- getLabels(User, Authorizations) - Method in interface org.apache.hadoop.hbase.security.visibility.ScanLabelGenerator
-
Helps to get a list of lables associated with an UGI
- getLabels(User, Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
-
- getLabels() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- getLabelsBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated string labels = 10;
- getLabelsBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
repeated string labels = 10;
- getLabelsBytes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
repeated string labels = 10;
- getLabelsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated string labels = 10;
- getLabelsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
repeated string labels = 10;
- getLabelsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
repeated string labels = 10;
- getLabelsCount() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getLabelsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- getLabelsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated string labels = 10;
- getLabelsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
repeated string labels = 10;
- getLabelsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
repeated string labels = 10;
- getLabelsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- getLargeCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getLargeCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getLargeCompactionThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getLargestHStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getLast(long[]) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
-
- getLast(List<T>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
-
- getLastAppliedOpAge() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- getLastAppliedOpAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- getLastAttemptAt() - Method in exception org.apache.hadoop.hbase.exceptions.PreemptiveFastFailException
-
- getLastCellIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getLastChild() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getLastCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getLastCompactSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 last_data_block_offset = 10;
- getLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 last_data_block_offset = 10;
- getLastDataBlockOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 last_data_block_offset = 10;
- getLastFanIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getLastFlushedSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
required uint64 last_flushed_sequence_id = 1;
- getLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
required uint64 last_flushed_sequence_id = 1;
- getLastFlushedSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIdsOrBuilder
-
required uint64 last_flushed_sequence_id = 1;
- getLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
required uint64 last_flushed_sequence_id = 1;
- getLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
required uint64 last_flushed_sequence_id = 1;
- getLastFlushedSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponseOrBuilder
-
required uint64 last_flushed_sequence_id = 1;
- getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.BlockingInterface
-
- getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest, RpcCallback<RegionServerStatusProtos.GetLastFlushedSequenceIdResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
-
rpc GetLastFlushedSequenceId(.GetLastFlushedSequenceIdRequest) returns (.GetLastFlushedSequenceIdResponse);
- getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest, RpcCallback<RegionServerStatusProtos.GetLastFlushedSequenceIdResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.Interface
-
rpc GetLastFlushedSequenceId(.GetLastFlushedSequenceIdRequest) returns (.GetLastFlushedSequenceIdResponse);
- getLastFlushedSequenceId(RpcController, RegionServerStatusProtos.GetLastFlushedSequenceIdRequest, RpcCallback<RegionServerStatusProtos.GetLastFlushedSequenceIdResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService.Stub
-
- getLastFlushTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
required uint64 last_flush_time = 1;
- getLastFlushTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
required uint64 last_flush_time = 1;
- getLastFlushTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
-
required uint64 last_flush_time = 1;
- getLastIndex(List<?>) - Static method in class org.apache.hadoop.hbase.util.CollectionUtils
-
- getLastKey() - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getLastKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getLastKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- getLastKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getLastKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the timestamp of the last major compaction for the passed table
The timestamp of the oldest HFile resulting from a major compaction of that table,
or 0 if no such HFile could be found.
- getLastMajorCompactionTimestamp(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getLastMajorCompactionTimestamp(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLastMajorCompactionTimestamp(RpcController, MasterProtos.MajorCompactionTimestampRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getLastMajorCompactionTimestamp(TableName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getLastMajorCompactionTimestamp(RpcController, MasterProtos.MajorCompactionTimestampRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- getLastMajorCompactionTimestamp(RpcController, MasterProtos.MajorCompactionTimestampRequest, RpcCallback<MasterProtos.MajorCompactionTimestampResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc getLastMajorCompactionTimestamp(.MajorCompactionTimestampRequest) returns (.MajorCompactionTimestampResponse);
- getLastMajorCompactionTimestamp(RpcController, MasterProtos.MajorCompactionTimestampRequest, RpcCallback<MasterProtos.MajorCompactionTimestampResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc getLastMajorCompactionTimestamp(.MajorCompactionTimestampRequest) returns (.MajorCompactionTimestampResponse);
- getLastMajorCompactionTimestamp(RpcController, MasterProtos.MajorCompactionTimestampRequest, RpcCallback<MasterProtos.MajorCompactionTimestampResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the timestamp of the last major compaction for the passed region.
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLastMajorCompactionTimestampForRegion(RpcController, MasterProtos.MajorCompactionTimestampForRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getLastMajorCompactionTimestampForRegion(RpcController, MasterProtos.MajorCompactionTimestampForRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- getLastMajorCompactionTimestampForRegion(RpcController, MasterProtos.MajorCompactionTimestampForRegionRequest, RpcCallback<MasterProtos.MajorCompactionTimestampResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc getLastMajorCompactionTimestampForRegion(.MajorCompactionTimestampForRegionRequest) returns (.MajorCompactionTimestampResponse);
- getLastMajorCompactionTimestampForRegion(RpcController, MasterProtos.MajorCompactionTimestampForRegionRequest, RpcCallback<MasterProtos.MajorCompactionTimestampResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc getLastMajorCompactionTimestampForRegion(.MajorCompactionTimestampForRegionRequest) returns (.MajorCompactionTimestampResponse);
- getLastMajorCompactionTimestampForRegion(RpcController, MasterProtos.MajorCompactionTimestampForRegionRequest, RpcCallback<MasterProtos.MajorCompactionTimestampResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- getLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 last_major_compaction_ts = 17 [default = 0];
- getLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint64 last_major_compaction_ts = 17 [default = 0];
- getLastMajorCompactionTs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint64 last_major_compaction_ts = 17 [default = 0];
- getLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getLastMajorCompactionTsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getLastMajorCompactionTsForTable(TableName) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getLastQuery() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
- getLastRecoveryTime() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
- getLastRecoveryTime() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- getLastRegion() - Method in class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
-
- getLastRegionServerUpdate() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Get the timestamp at which the last change occurred to the list of region servers to replicate
to.
- getLastRowKey() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
TODO left from
HFile
version 1: move this to StoreFile after
Ryan's patch goes in to eliminate
KeyValue
here.
- getLastRowKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getLastRowKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getLastSequenceId(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getLastSequenceId(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.LastSequenceId
-
- getLastShippedAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- getLastShippedAge() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- getLastShippedAge() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- getLastUpdate() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getLastUpdate() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional uint64 last_update = 3;
- getLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
optional uint64 last_update = 3;
- getLastUpdate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
-
optional uint64 last_update = 3;
- getLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required uint64 last_update = 8;
- getLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
required uint64 last_update = 8;
- getLastUpdate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
required uint64 last_update = 8;
- getLastUpdate() - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
- getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Get whether only the latest version of the column value should be compared.
- getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bool latest_version_only = 6;
- getLatestVersionOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
optional bool latest_version_only = 6;
- getLatestVersionOnly() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
optional bool latest_version_only = 6;
- getLeafWriters() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
-
- getLeases() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getLeases() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getLeastSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
required uint64 least_sig_bits = 1;
- getLeastSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
required uint64 least_sig_bits = 1;
- getLeastSigBits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUIDOrBuilder
-
required uint64 least_sig_bits = 1;
- getLeaves() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
-
- getLeaves() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
-
- getLegacyKeyComparatorName() - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
The HFileV2 file format's trailer contains this class name.
- getLegacyKeyComparatorName() - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
The HFileV2 file format's trailer contains this class name.
- getLegacyKeyComparatorName() - Method in class org.apache.hadoop.hbase.KeyValue.RawBytesComparator
-
The HFileV2 file format's trailer contains this class name.
- getLenAsVal() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
-
required bool len_as_val = 1;
- getLenAsVal() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
required bool len_as_val = 1;
- getLenAsVal() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilterOrBuilder
-
required bool len_as_val = 1;
- getLength() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- getLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getLength() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the length of the split.
- getLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required uint32 length = 2;
- getLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
required uint32 length = 2;
- getLength() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
-
required uint32 length = 2;
- getLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
-
optional uint32 length = 1;
- getLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
optional uint32 length = 1;
- getLength() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMetaOrBuilder
-
optional uint32 length = 1;
- getLength() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
- getLength() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- getLength() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
Retrieve the maximum length (in bytes) of encoded values.
- getLength() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getLength() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The length of the range.
- getLength() - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
-
- getLevel0Files() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
- getLevel0Files() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getLevel0MinFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
-
- getLimit() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
-
required int32 limit = 1;
- getLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
required int32 limit = 1;
- getLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilterOrBuilder
-
required int32 limit = 1;
- getLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
required int32 limit = 1;
- getLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
required int32 limit = 1;
- getLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
-
required int32 limit = 1;
- getLimit() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- getLimit() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- getLimit() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getLimit() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Return the current limit
- getLimit__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- getLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional int32 line_number = 4;
- getLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
optional int32 line_number = 4;
- getLineNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
optional int32 line_number = 4;
- getListener() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getListener() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler.Context
-
- getListenerAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Return the socket (ip+port) on which the RPC server is listening to.
- getListenerAddress() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- getListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Get a copy of current registered listeners
- getListOfRegionServers() - Method in interface org.apache.hadoop.hbase.replication.ReplicationTracker
-
Returns a list of other live region servers in the cluster.
- getListOfRegionServers() - Method in class org.apache.hadoop.hbase.replication.ReplicationTrackerZKImpl
-
Return a snapshot of the current region servers.
- getListOfReplicators() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Get a list of all region servers that have outstanding replication queues.
- getListOfReplicators() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
-
Get a list of all region servers that have outstanding replication queues.
- getListOfReplicators() - Method in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
- getLiveMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getLiveNode(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getLiveNodes() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getLiveNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveNodesOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- getLiveRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getLiveServers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServers(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .LiveServerInfo live_servers = 2;
- getLiveServersOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .LiveServerInfo live_servers = 2;
- getLoad(ServerName) - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getLoad(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
optional .ServerLoad load = 2;
- getLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
optional .ServerLoad load = 2;
- getLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
-
optional .ServerLoad load = 2;
- getLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Originally, this method factored in the effect of requests going to the
server as well.
- getLoadBalancer(Configuration) - Static method in class org.apache.hadoop.hbase.master.balancer.LoadBalancerFactory
-
Create a loadbalancer from the given conf.
- getLoadBalancerClassName() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getLoadBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
optional .ServerLoad load = 2;
- getLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool load_column_families_on_demand = 13;
- getLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bool load_column_families_on_demand = 13;
- getLoadColumnFamiliesOnDemand() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bool load_column_families_on_demand = 13;
- getLoadColumnFamiliesOnDemandValue() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the raw loadColumnFamiliesOnDemand setting; if it's not set, can be null.
- getLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
-
required bool loaded = 1;
- getLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
required bool loaded = 1;
- getLoaded() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponseOrBuilder
-
required bool loaded = 1;
- getLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
-
required bool loaded = 1;
- getLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
required bool loaded = 1;
- getLoaded() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponseOrBuilder
-
required bool loaded = 1;
- getLoadedCachedBlocksByFile(Configuration, BlockCache) - Static method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil
-
- getLoadedCoprocessors() - Static method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- getLoadedCoprocessors() - Static method in class org.apache.hadoop.hbase.master.HMaster
-
The set of loaded coprocessors is stored in a static set.
- getLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 load_on_open_data_offset = 2;
- getLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 load_on_open_data_offset = 2;
- getLoadOnOpenDataOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 load_on_open_data_offset = 2;
- getLoadOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
optional .ServerLoad load = 2;
- getLoadOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
optional .ServerLoad load = 2;
- getLoadOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
-
optional .ServerLoad load = 2;
- getLoadSequence() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getLoadSequence() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getLoadStats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .RegionLoadStats loadStats = 5;
- getLoadStats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional .RegionLoadStats loadStats = 5;
- getLoadStats() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional .RegionLoadStats loadStats = 5;
- getLoadStatsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .RegionLoadStats loadStats = 5;
- getLoadStatsOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .RegionLoadStats loadStats = 5;
- getLoadStatsOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional .RegionLoadStats loadStats = 5;
- getLoadStatsOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional .RegionLoadStats loadStats = 5;
- getLocalFs(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Wrap a LocalFileSystem within a HFileSystem.
- getLocalTableDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getLocation(boolean) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- getLocation() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getLocation() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- getLocation() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- getLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional string location = 5;
- getLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
optional string location = 5;
- getLocation() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
optional string location = 5;
- getLocationBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional string location = 5;
- getLocationBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
optional string location = 5;
- getLocationBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
optional string location = 5;
- getLocations() - Method in class org.apache.hadoop.hbase.io.FileLink
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat.TableSnapshotRegionSplit
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getLocations() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region's location as an array.
- getLocations(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
repeated string locations = 2;
- getLocations(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
repeated string locations = 2;
- getLocations(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplitOrBuilder
-
repeated string locations = 2;
- getLocationsBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
repeated string locations = 2;
- getLocationsBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
repeated string locations = 2;
- getLocationsBytes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplitOrBuilder
-
repeated string locations = 2;
- getLocationsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
repeated string locations = 2;
- getLocationsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
repeated string locations = 2;
- getLocationsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplitOrBuilder
-
repeated string locations = 2;
- getLocationSeqNum() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getLocationsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
repeated string locations = 2;
- getLocationsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
repeated string locations = 2;
- getLocationsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplitOrBuilder
-
repeated string locations = 2;
- getLockedRows() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getLockEntry(long) - Method in class org.apache.hadoop.hbase.util.IdLock
-
Blocks until the lock corresponding to the given id is acquired.
- getLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
required string lock_owner = 1;
- getLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
required string lock_owner = 1;
- getLockOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLockOrBuilder
-
required string lock_owner = 1;
- getLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .ServerName lock_owner = 2;
- getLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional .ServerName lock_owner = 2;
- getLockOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional .ServerName lock_owner = 2;
- getLockOwnerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .ServerName lock_owner = 2;
- getLockOwnerBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
required string lock_owner = 1;
- getLockOwnerBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
required string lock_owner = 1;
- getLockOwnerBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLockOrBuilder
-
required string lock_owner = 1;
- getLockOwnerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .ServerName lock_owner = 2;
- getLockOwnerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional .ServerName lock_owner = 2;
- getLockOwnerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional .ServerName lock_owner = 2;
- getLockPath(String, List<String>) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Determine based on a list of children under a ZNode, whether or not a
process which created a specified ZNode has obtained a lock.
- getLockPath(String, List<String>) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessReadLock
-
Determine based on a list of children under a ZNode, whether or not a
process which created a specified ZNode has obtained a lock.
- getLockPath(String, List<String>) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessWriteLock
-
Determine based on a list of children under a ZNode, whether or not a
process which created a specified ZNode has obtained a lock.
- getLockZNode(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- getLog(HRegionInfo) - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
- getLogDir() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- getLogDir() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the directory where wals are stored by their RSs
- getLogFilePath(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- getLogFileSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getLogFileSize(WALFactory) - Static method in class org.apache.hadoop.hbase.wal.BoundedRegionGroupingProvider
-
iff the given WALFactory is using the BoundedRegionGroupingProvider for meta and/or non-meta,
count the size of files (rolled and active).
- getLogFileSize(WALFactory) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
iff the given WALFactory is using the DefaultWALProvider for meta and/or non-meta,
count the size of files (rolled and active).
- getLogId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
- getLogId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint64 log_id = 3;
- getLogId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
required uint64 log_id = 3;
- getLogId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeaderOrBuilder
-
required uint64 log_id = 3;
- getLogPosition(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Get the current position for a specific WAL in a given queue.
- getLogPosition(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- getLogRecoveryMode() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getLogsCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getLogsDir(Path, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Get log directory for a server in a snapshot.
- getLogSeqNum() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional uint64 log_sequence_number = 4;
- getLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
optional uint64 log_sequence_number = 4;
- getLogSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
optional uint64 log_sequence_number = 4;
- getLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required uint64 log_sequence_number = 3;
- getLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
required uint64 log_sequence_number = 3;
- getLogSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
required uint64 log_sequence_number = 3;
- getLogsInQueue(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Get a list of all WALs in the given queue.
- getLogsInQueue(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
-
Get a list of all WALs in the given queue on the given region server.
- getLogsInQueue(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
-
- getLogsInQueue(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- getLogsSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getLong(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.TimestampDecoder
-
methods
- getLong(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getLong() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the long value at index
- getLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next long value from this range.
- getLong(byte[]) - Static method in class org.apache.hadoop.hbase.util.vint.UVLongTool
-
bytes -> long
- getLong(byte[], int) - Static method in class org.apache.hadoop.hbase.util.vint.UVLongTool
-
- getLong(InputStream) - Static method in class org.apache.hadoop.hbase.util.vint.UVLongTool
-
- getLongCounter(String, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Get a MetricMutableCounterLong from the storage.
- getLongGauge(String, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Get a MetricMutableGaugeLong from the storage.
- getLongMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
-
required int64 long_msg = 1;
- getLongMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
required int64 long_msg = 1;
- getLongMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsgOrBuilder
-
required int64 long_msg = 1;
- getLowestTimestamp(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Gets lowest timestamp from candidate StoreFiles
- getMajor() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
optional bool major = 2;
- getMajor() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
optional bool major = 2;
- getMajor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
-
optional bool major = 2;
- getMajorCompactedCellsCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMajorCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of cells processed during major compactions.
- getMajorCompactedCellsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getMajorCompactedCellsSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMajorCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total amount of data processed during major compactions, in bytes.
- getMajorCompactedCellsSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getMajorCompactionJitter() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMajorCompactionPeriod() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Returns the major version of this HFile format
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- getMajorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
-
- getMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to all versions of its qualifiers and values.
- getMapEntries(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- getMapEntries(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
repeated .NameStringPair map_entries = 1;
- getMapEntries(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponseOrBuilder
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponseOrBuilder
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponseOrBuilder
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponseOrBuilder
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
repeated .NameStringPair map_entries = 1;
- getMapEntriesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponseOrBuilder
-
repeated .NameStringPair map_entries = 1;
- getMapEntry(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntry(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntry(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProtoOrBuilder
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProtoOrBuilder
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProtoOrBuilder
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProtoOrBuilder
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
repeated .BytesBytesPair map_entry = 1;
- getMapEntryOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProtoOrBuilder
-
repeated .BytesBytesPair map_entry = 1;
- getMapperClass(JobContext) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Get the application's mapper class.
- getMaster() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Returns a MasterKeepAliveConnection
to the active master
- getMaster() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
internal method, do not use thru HConnection
- getMaster() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
Returns detailed information about the current master
ServerName
.
- getMaster() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
- getMaster(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ServerName master = 7;
- getMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
optional .ServerName master = 7;
- getMaster() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
optional .ServerName master = 7;
- getMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
required .ServerName master = 1;
- getMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
required .ServerName master = 1;
- getMaster() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
-
required .ServerName master = 1;
- getMaster() - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl.ImplData
-
- getMaster() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getMaster() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
-
- getMaster() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread
-
- getMasterActiveTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterAddress() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the address of the current master if one is available.
- getMasterAddress(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the address of the current master if one is available.
- getMasterAddress(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get master address.
- getMasterAddressTracker() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getMasterAddressZNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- getMasterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ServerName master = 7;
- getMasterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
required .ServerName master = 1;
- getMasterConfiguration() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getMasterCoprocessorHost() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterCoprocessorHost() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterCoprocessorHost() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getMasterCoprocessors() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Helper delegage to getClusterStatus().getMasterCoprocessors().
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterCoprocessors(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessors(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessors(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterCoprocessorsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .Coprocessor master_coprocessors = 6;
- getMasterFileSystem() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterFileSystem() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterInfoPort() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the info port of the current master if one is available.
- getMasterInfoPort() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getMasterInfoPort() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get the info port of the current master of one is available.
- getMasterInfoPort(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Get master info port.
- getMasterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ServerName master = 7;
- getMasterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
optional .ServerName master = 7;
- getMasterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
optional .ServerName master = 7;
- getMasterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
required .ServerName master = 1;
- getMasterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
required .ServerName master = 1;
- getMasterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
-
required .ServerName master = 1;
- getMasterProcedureExecutor() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterProcedureExecutor() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterQuotaManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterQuotaManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getMasterQuotaManager(MasterProcedureEnv) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- getMasterRpcServices() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasters() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getMasterServices() - Method in interface org.apache.hadoop.hbase.coprocessor.MasterCoprocessorEnvironment
-
- getMasterServices() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getMasterStartTime() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
optional uint64 master_system_time = 4;
- getMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
optional uint64 master_system_time = 4;
- getMasterSystemTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
-
optional uint64 master_system_time = 4;
- getMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
optional uint64 master_system_time = 5;
- getMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
optional uint64 master_system_time = 5;
- getMasterSystemTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
-
optional uint64 master_system_time = 5;
- getMasterSystemTime() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
-
- getMasterSystemTime() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getMatchingNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
-
- getMax(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives the maximum for a given combination of column qualifier and column
family, in the given row range as defined in the Scan object.
- getMax() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- getMax() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
- getMax(RpcController, AggregateProtos.AggregateRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
-
- getMax(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
rpc GetMax(.AggregateRequest) returns (.AggregateResponse);
- getMax(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
-
rpc GetMax(.AggregateRequest) returns (.AggregateResponse);
- getMax(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
-
- getMax() - Method in class org.apache.hadoop.metrics2.lib.MutableHistogram
-
- getMaxAllowedOperationTime() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getMaxAttempts() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- getMaxAttempts() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- getMaxChunkSize(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
- getMaxColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMaxColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bytes max_column = 3;
- getMaxColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
optional bytes max_column = 3;
- getMaxColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
-
optional bytes max_column = 3;
- getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bool max_column_inclusive = 4;
- getMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
optional bool max_column_inclusive = 4;
- getMaxColumnInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
-
optional bool max_column_inclusive = 4;
- getMaxCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMaxElementLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- getMaxFileDescriptorCount() - Method in class org.apache.hadoop.hbase.util.JVM
-
Get the number of the maximum file descriptors the system can use.
- getMaxFileSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the maximum size upto which a region can grow to after which a region
split is triggered.
- getMaxFilesToCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMaxFlushedSeqId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMaxFlushedSeqId() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getMaxFold(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- getMaxHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint32 max_heap_MB = 4;
- getMaxHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint32 max_heap_MB = 4;
- getMaxHeapMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint32 max_heap_MB = 4;
- getMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int32 maxHeapSizeMB = 5;
- getMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
optional int32 maxHeapSizeMB = 5;
- getMaxHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
optional int32 maxHeapSizeMB = 5;
- getMaximumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- getMaxKeys() - Method in interface org.apache.hadoop.hbase.util.BloomFilterBase
-
- getMaxKeys(Configuration) - Static method in class org.apache.hadoop.hbase.util.BloomFilterFactory
-
- getMaxKeys() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getMaxKeys() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
- getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getMaxKeyValueSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getMaxKeyValueSize(Configuration) - Static method in class org.apache.hadoop.hbase.client.HTable
-
- getMaxLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getMaxLatencyForEachRegionServer() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getMaxMasterTimeout(Configuration, HBaseProtos.SnapshotDescription.Type, long) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- getMaxMemstoreTS() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMaxMemstoreTS() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getMaxMemstoreTS() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getMaxMemstoreTSInList(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Return the largest memstoreTS found across all storefiles in
the given list.
- getMaxMerge() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getMaxOverlapsToSideline() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getMaxPoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getMaxPoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getMaxProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- getMaxProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
- getMaxQualifierLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getMaxQueueSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getMaxQueueSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getMaxRegions(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getMaxResultSize() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getMaxResultSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint64 max_result_size = 10;
- getMaxResultSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional uint64 max_result_size = 10;
- getMaxResultSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional uint64 max_result_size = 10;
- getMaxResultSize() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's maximum number of values
to return per Column Family
- getMaxResultsPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getMaxRowLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getMaxRowTreeStackNodes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- getMaxSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMaxSequenceId() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getMaxSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getMaxSequenceIdInList(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Return the highest sequence ID found across all storefiles in
the given list.
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getMaxSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get the maximum size of this cache.
- getMaxSleepTime() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- getMaxSplitImbalance() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getMaxStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- getMaxStoreSeqId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMaxStoreSeqId() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getMaxTables(NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- getMaxTagsLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getMaxTime() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
- getMaxTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getMaxValue() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
returns the maximum value for this type T
- getMaxValues() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's maximum number of version
- getMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional uint32 max_versions = 6 [default = 1];
- getMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional uint32 max_versions = 6 [default = 1];
- getMaxVersions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional uint32 max_versions = 6 [default = 1];
- getMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 max_versions = 7 [default = 1];
- getMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional uint32 max_versions = 7 [default = 1];
- getMaxVersions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional uint32 max_versions = 7 [default = 1];
- getMaxVersions() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional int32 maxVersions = 4;
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
optional int32 maxVersions = 4;
- getMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
optional int32 maxVersions = 4;
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int32 maxVersions = 7;
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional int32 maxVersions = 7;
- getMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional int32 maxVersions = 7;
- getMaxVersions() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getMaxVersions() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getMayInterruptIfRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
optional bool mayInterruptIfRunning = 2 [default = true];
- getMayInterruptIfRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
optional bool mayInterruptIfRunning = 2 [default = true];
- getMayInterruptIfRunning() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequestOrBuilder
-
optional bool mayInterruptIfRunning = 2 [default = true];
- getMD5AsHex(byte[]) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
-
Given a byte array, returns in MD5 hash as a hex string.
- getMD5AsHex(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.MD5Hash
-
Given a byte array, returns its MD5 hash as a hex string.
- getMean() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- getMean() - Method in class org.apache.hadoop.metrics2.lib.MutableHistogram
-
- getMechanismName() - Method in enum org.apache.hadoop.hbase.security.AuthMethod
-
Return the SASL mechanism name
- getMedian(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives a List containing sum of values and sum of weights.
- getMedian(RpcController, AggregateProtos.AggregateRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
-
- getMedian(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
rpc GetMedian(.AggregateRequest) returns (.AggregateResponse);
- getMedian(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
-
rpc GetMedian(.AggregateRequest) returns (.AggregateResponse);
- getMedian(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
-
- getMemberName() - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Each subprocedure is being executed on a member.
- getMemberName() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- getMemberName() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- getMemFree() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the currently available memory for this LRU in bytes.
- getMemMax() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the maximum memory allowed for this LRU in bytes.
- getMemStoreFlushSize() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the size of the memstore after which a flush to filesystem is triggered.
- getMemstoreFlushSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMemstoreFlushSize() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
- getMemstoreLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
optional int32 memstoreLoad = 1 [default = 0];
- getMemstoreLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
optional int32 memstoreLoad = 1 [default = 0];
- getMemstoreLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStatsOrBuilder
-
optional int32 memstoreLoad = 1 [default = 0];
- getMemstoreLoadPercent() - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- getMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- getMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMemStoreSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getMemstoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the memstore on this region server.
- getMemstoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the size of the memstore on this region server.
- getMemstoreSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getMemstoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getMemStoreSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getMemstoreSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 memstore_size_MB = 6;
- getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 memstore_size_MB = 6;
- getMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 memstore_size_MB = 6;
- getMemStoreSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 memstoreSizeMB = 5;
- getMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 memstoreSizeMB = 5;
- getMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 memstoreSizeMB = 5;
- getMemUsed() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the currently used memory for this LRU in bytes.
- getMergedRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
- getMergedRegionInfo(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
Get merged region info through the specified two regions
- getMergedRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- getMergeRegions(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
- getMergeRegions(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the merge regions by reading the corresponding columns of the catalog table
Result.
- getMergeThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getMessage() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional string message = 2;
- getMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
optional string message = 2;
- getMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
optional string message = 2;
- getMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- getMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- getMessage() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- getMessage() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- getMessage() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- getMessageBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional string message = 2;
- getMessageBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
optional string message = 2;
- getMessageBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
optional string message = 2;
- getMetaBlock(String, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getMetaBlock(String, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- getMetadataValue(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Only used by the Striped Compaction Policy
- getMetaIndexCount() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getMetaIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 meta_index_count = 6;
- getMetaIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint32 meta_index_count = 6;
- getMetaIndexCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint32 meta_index_count = 6;
- getMetaKeyForRegion(HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the row key to use for this regionInfo
- getMetaLocation() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getMetaLocation__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getMetaOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getMetaRegion() - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
- getMetaRegionLocation(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Gets the meta region location, if available.
- getMetaRegionLocation(ZooKeeperWatcher, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Gets the meta region location, if available.
- getMetaRegions(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
- getMetaRegions(ZooKeeperWatcher, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
- getMetaRegionsAndLocations(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
- getMetaRegionsAndLocations(ZooKeeperWatcher, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
- getMetaRegionState(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Load the meta region state from the meta server ZNode.
- getMetaRegionState(ZooKeeperWatcher, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Load the meta region state from the meta server ZNode.
- getMetaReplicaIdFromZnode(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Parse the meta replicaId from the passed znode
- getMetaReplicaNodes() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Get the znodes corresponding to the meta replicas from ZK
- getMetaTableLocator() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getMetaTableLocator() - Method in interface org.apache.hadoop.hbase.Server
-
- getMetaWAL(byte[]) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getMetaWriter() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Get a writable interface into bloom filter meta data.
- getMetaWriter() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- getMetaWriter() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- getMethod() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getMethod() - Method in interface org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.HttpInteraction
-
Returns the method.
- getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required string method_name = 3;
- getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
required string method_name = 3;
- getMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
-
required string method_name = 3;
- getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string method_name = 2;
- getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
optional string method_name = 2;
- getMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
optional string method_name = 2;
- getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional string method_name = 3;
- getMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional string method_name = 3;
- getMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional string method_name = 3;
- getMethodNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required string method_name = 3;
- getMethodNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
required string method_name = 3;
- getMethodNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
-
required string method_name = 3;
- getMethodNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string method_name = 2;
- getMethodNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
optional string method_name = 2;
- getMethodNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
optional string method_name = 2;
- getMethodNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional string method_name = 3;
- getMethodNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional string method_name = 3;
- getMethodNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional string method_name = 3;
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- getMetrics() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the metrics instance for reporting RPC call statistics
- getMetrics() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Returns the metrics instance for reporting RPC call statistics
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- getMetrics(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- getMetrics(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
repeated .NameInt64Pair metrics = 1;
- getMetrics(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetricsOrBuilder
-
repeated .NameInt64Pair metrics = 1;
- getMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
-
Yes this is a get function that doesn't return anything.
- getMetrics(MetricsCollector, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
-
Yes this is a get function that doesn't return anything.
- getMetrics() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getMetrics() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getMetricsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- getMetricsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- getMetricsContext() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Get the metrics context.
- getMetricsContext() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- getMetricsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- getMetricsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
repeated .NameInt64Pair metrics = 1;
- getMetricsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetricsOrBuilder
-
repeated .NameInt64Pair metrics = 1;
- getMetricsDescription() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Get the description of what this source exposes.
- getMetricsDescription() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- getMetricsJmxContext() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Get the name of the context in JMX that this source will be exposed through.
- getMetricsJmxContext() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- getMetricsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- getMetricsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
repeated .NameInt64Pair metrics = 1;
- getMetricsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetricsOrBuilder
-
repeated .NameInt64Pair metrics = 1;
- getMetricsMap() - Method in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
Get all of the values since the last time this function was called.
- getMetricsName() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Get the name of the metrics that are being exported by this source.
- getMetricsName() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- getMetricsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- getMetricsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
repeated .NameInt64Pair metrics = 1;
- getMetricsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetricsOrBuilder
-
repeated .NameInt64Pair metrics = 1;
- getMetricsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- getMetricsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
repeated .NameInt64Pair metrics = 1;
- getMetricsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetricsOrBuilder
-
repeated .NameInt64Pair metrics = 1;
- getMetricsRegistry() - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
- getMetricsSource() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
-
- getMetricsSource() - Method in class org.apache.hadoop.hbase.master.MetricsMaster
-
- getMetricsSource() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- getMidpoint(KeyValue.KVComparator, Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
-
Try to return a Cell that falls between left
and right
but that is
shorter; i.e.
- getMin() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
get/set
- getMin(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives the minimum for a given combination of column qualifier and column
family, in the given row range as defined in the Scan object.
- getMin() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
Gets the minimum timestamp requested by filter.
- getMin() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- getMin() - Method in class org.apache.hadoop.hbase.io.TimeRange
-
- getMin(RpcController, AggregateProtos.AggregateRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
-
- getMin(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
rpc GetMin(.AggregateRequest) returns (.AggregateResponse);
- getMin(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
-
rpc GetMin(.AggregateRequest) returns (.AggregateResponse);
- getMin(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
-
- getMin() - Method in class org.apache.hadoop.metrics2.lib.MutableHistogram
-
- getMinColumn() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMinColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bytes min_column = 1;
- getMinColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
optional bytes min_column = 1;
- getMinColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
-
optional bytes min_column = 1;
- getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bool min_column_inclusive = 2;
- getMinColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
optional bool min_column_inclusive = 2;
- getMinColumnInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
-
optional bool min_column_inclusive = 2;
- getMinCompactSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMinFilesToCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMinimumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getMinimumTimestamp() - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
-
- getMinIndexNumEntries(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
- getMinLocalityToForceCompact() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getMinMvccVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getMinorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
Returns the minor version of this HFile format
- getMinorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- getMinorVersion() - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
-
- getMinProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- getMinProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- getMinProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
- getMinProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint64 min_proc_id = 4;
- getMinProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
required uint64 min_proc_id = 4;
- getMinProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeaderOrBuilder
-
required uint64 min_proc_id = 4;
- getMinStamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- getMinTimestamp() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getMinValue() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getMinValue() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- getMinVersions() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getMinVersions() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getMissCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMissCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getMissCachingRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMissCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getMissCount() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the number of misses to the map.
- getMissing() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getMissingLogsCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getMissingStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getMissRatio() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getMode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN];
- getMode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN];
- getMode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
-
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN];
- getMode() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- getModificationTime() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getModificationTimeStamp() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getModifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .TableSchema modified_table_schema = 3;
- getModifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
required .TableSchema modified_table_schema = 3;
- getModifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
-
required .TableSchema modified_table_schema = 3;
- getModifiedTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .TableSchema modified_table_schema = 3;
- getModifiedTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .TableSchema modified_table_schema = 3;
- getModifiedTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
required .TableSchema modified_table_schema = 3;
- getModifiedTableSchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
-
required .TableSchema modified_table_schema = 3;
- getMonitor() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
- getMoreResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool more_results = 3;
- getMoreResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
optional bool more_results = 3;
- getMoreResults() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
optional bool more_results = 3;
- getMoreResultsInRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool more_results_in_region = 8;
- getMoreResultsInRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
optional bool more_results_in_region = 8;
- getMoreResultsInRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
optional bool more_results_in_region = 8;
- getMostLoadedRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Get the top N most loaded regions this server is serving so we can tell the
master which regions it can reallocate if we're overloaded.
- getMostSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
required uint64 most_sig_bits = 2;
- getMostSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
required uint64 most_sig_bits = 2;
- getMostSigBits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUIDOrBuilder
-
required uint64 most_sig_bits = 2;
- getMput() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
mutation for the put
- getMTime() - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- getMultiple(ByteBuffer, List<TGet>, AsyncMethodCallback<THBaseService.AsyncClient.getMultiple_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- getMultiple(ByteBuffer, List<TGet>, AsyncMethodCallback<THBaseService.AsyncClient.getMultiple_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- getMultiple(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- getMultiple(ByteBuffer, List<TGet>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Method for getting multiple rows.
- getMultiple(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getMultiple(long, int, byte[]) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
-
Transfers bytes from this buffer array into the given destination array
- getMultiple(long, int, byte[], int) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
-
Transfers bytes from this buffer array into the given destination array
- getMultipleRowResource(String) - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getMutateType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .MutationProto.MutationType mutate_type = 2;
- getMutateType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional .MutationProto.MutationType mutate_type = 2;
- getMutateType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional .MutationProto.MutationType mutate_type = 2;
- getMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .MutationProto mutation = 2;
- getMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
optional .MutationProto mutation = 2;
- getMutation() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
-
optional .MutationProto mutation = 2;
- getMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .MutationProto mutation = 2;
- getMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
required .MutationProto mutation = 2;
- getMutation() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
-
required .MutationProto mutation = 2;
- getMutationBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .MutationProto mutation = 2;
- getMutationBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .MutationProto mutation = 2;
- getMutationOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .MutationProto mutation = 2;
- getMutationOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
optional .MutationProto mutation = 2;
- getMutationOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
-
optional .MutationProto mutation = 2;
- getMutationOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .MutationProto mutation = 2;
- getMutationOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
required .MutationProto mutation = 2;
- getMutationOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
-
required .MutationProto mutation = 2;
- getMutationRequest(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- getMutationRequest(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
repeated .MutationProto mutation_request = 1;
- getMutationRequest(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequestOrBuilder
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequestOrBuilder
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequestOrBuilder
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequestOrBuilder
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
repeated .MutationProto mutation_request = 1;
- getMutationRequestOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequestOrBuilder
-
repeated .MutationProto mutation_request = 1;
- getMutations() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- getMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- getMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
list of mutation commands
- getMutations() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
list of mutation commands
- getMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- getMutationsFromWALEntry(AdminProtos.WALEntry, CellScanner, Pair<WALKey, WALEdit>, Durability) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
This function is used to construct mutations from a WALEntry.
- getMutationsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- getMutationsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- getMutationsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- getMutationsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- getMutationsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- getMutationsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- getMutationsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- getMutationsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- getMVCC() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getMvccReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getMvccVersion() - Method in interface org.apache.hadoop.hbase.Cell
-
Deprecated.
as of 1.0, use Cell.getSequenceId()
Internal use only. A region-specific sequence ID given to each operation. It always exists for
cells in the memstore but is not retained forever. It may survive several flushes, but
generally becomes irrelevant after the cell's row is no longer involved in any operations that
require strict consistency.
- getMvccVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getMvccVersion(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.timestamp.MvccVersionDecoder
-
methods
- getMvccVersion() - Method in class org.apache.hadoop.hbase.KeyValue
-
Here be dragons
- getMvccVersion() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
Deprecated.
- getMvccVersionDeltaWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getMvccVersionEncoder() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getMvccVersionIndex(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getMvccVersionIndexWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getMvccVersions() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getMWrap() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
-
- getMyEphemeralNodeFileName() - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
Get the name of the file used to store the znode contents
- getName() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Gets the fully qualified table name instance of the table that this BufferedMutator writes to.
- getName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getName() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
- getName() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getName() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getName() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the fully qualified table name instance of this table.
- getName() - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets the fully qualified table name instance of this table.
- getName() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- getName() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getName() - Method in enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
-
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return this Cipher's name
- getName() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Return the provider's name
- getName() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getName() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getName() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
Returns this reader's "name".
- getName() - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- getName() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- getName() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
required string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ComparatorOrBuilder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
required string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterOrBuilder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
required bytes name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
required bytes name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
-
required bytes name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
required string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CoprocessorOrBuilder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
required string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPairOrBuilder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
optional string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
optional string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64PairOrBuilder
-
optional string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
required bytes name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
required bytes name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptorOrBuilder
-
required bytes name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
required string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPairOrBuilder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
required string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
required string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFileOrBuilder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getName() - Method in class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
-
- getName() - Method in exception org.apache.hadoop.hbase.regionserver.Leases.LeaseStillHeldException
-
- getName() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Human readable name of the processor
- getName() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.TableModel
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- getName() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
required string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
optional string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
optional string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
required string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
required bytes name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
required bytes name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
required bytes name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
required string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
required string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
required string name = 1;
- getName(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
repeated string name = 1;
- getName(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
repeated string name = 1;
- getName(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
-
repeated string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
required string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
-
required string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
optional string name = 1;
- getName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
optional string name = 1;
- getName() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getName() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- getName() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the full user name.
- getName() - Method in class org.apache.hadoop.hbase.TableName
-
- getName() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getName() - Method in enum org.apache.hadoop.hbase.util.ChecksumType
-
returns the name of this checksum type
- getName() - Method in class org.apache.hadoop.hbase.util.HasThread
-
- getName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Get the name of the table as a String
- getNameAsString() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getNameAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
required string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ComparatorOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
required string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
required string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CoprocessorOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
required string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPairOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
optional string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
optional string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64PairOrBuilder
-
optional string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
required string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPairOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
required string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
required string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFileOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
required string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
optional string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
optional string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
required string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
required string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
required string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
required string name = 1;
- getNameBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
repeated string name = 1;
- getNameBytes(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
repeated string name = 1;
- getNameBytes(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
-
repeated string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
required string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
-
required string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional string name = 1;
- getNameBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
optional string name = 1;
- getNameBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
optional string name = 1;
- getNameCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
repeated string name = 1;
- getNameCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
repeated string name = 1;
- getNameCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
-
repeated string name = 1;
- getNamedThreadFactory(String) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Returns a
ThreadFactory
that names each created thread uniquely,
with a common prefix.
- getNameFromId(short) - Static method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
Find and return the name of data block encoder for the given id.
- getNameInBytes() - Method in enum org.apache.hadoop.hbase.io.encoding.DataBlockEncoding
-
- getNameList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
repeated string name = 1;
- getNameList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
repeated string name = 1;
- getNameList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableListOrBuilder
-
repeated string name = 1;
- getNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
required bytes namespace = 1;
- getNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
required bytes namespace = 1;
- getNamespace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableNameOrBuilder
-
required bytes namespace = 1;
- getNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional string namespace = 4;
- getNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
optional string namespace = 4;
- getNamespace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
optional string namespace = 4;
- getNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional string namespace = 3;
- getNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
optional string namespace = 3;
- getNamespace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequestOrBuilder
-
optional string namespace = 3;
- getNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string namespace = 3;
- getNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional string namespace = 3;
- getNamespace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional string namespace = 3;
- getNamespace() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getNamespace() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the name of the namespace this table is in.
- getNamespace() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNamespace() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getNamespace() - Method in class org.apache.hadoop.hbase.TableName
-
- getNamespaceAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getNamespaceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional string namespace = 4;
- getNamespaceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
optional string namespace = 4;
- getNamespaceBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
optional string namespace = 4;
- getNamespaceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional string namespace = 3;
- getNamespaceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
optional string namespace = 3;
- getNamespaceBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequestOrBuilder
-
optional string namespace = 3;
- getNamespaceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string namespace = 3;
- getNamespaceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional string namespace = 3;
- getNamespaceBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional string namespace = 3;
- getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get a namespace descriptor by name
- getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get a namespace descriptor by name
- getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getNamespaceDescriptor(RpcController, MasterProtos.GetNamespaceDescriptorRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getNamespaceDescriptor(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Get a namespace descriptor by name
- getNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequestOrBuilder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponseOrBuilder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptor(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptor(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptor(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponseOrBuilder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptor(RpcController, MasterProtos.GetNamespaceDescriptorRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- getNamespaceDescriptor(RpcController, MasterProtos.GetNamespaceDescriptorRequest, RpcCallback<MasterProtos.GetNamespaceDescriptorResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc GetNamespaceDescriptor(.GetNamespaceDescriptorRequest) returns (.GetNamespaceDescriptorResponse);
- getNamespaceDescriptor(RpcController, MasterProtos.GetNamespaceDescriptorRequest, RpcCallback<MasterProtos.GetNamespaceDescriptorResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc GetNamespaceDescriptor(.GetNamespaceDescriptorRequest) returns (.GetNamespaceDescriptorResponse);
- getNamespaceDescriptor(RpcController, MasterProtos.GetNamespaceDescriptorRequest, RpcCallback<MasterProtos.GetNamespaceDescriptorResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- getNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequestOrBuilder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponseOrBuilder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponseOrBuilder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequestOrBuilder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponseOrBuilder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponseOrBuilder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequestOrBuilder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDescriptorOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponseOrBuilder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- getNamespaceDir(Path, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the Path
object representing
the namespace directory under path rootdir
- getNamespaceFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
- getNamespaceFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getNamespaceLimiter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified namespace.
- getNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional bytes namespace_name = 3;
- getNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
optional bytes namespace_name = 3;
- getNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequestOrBuilder
-
optional bytes namespace_name = 3;
- getNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
optional bytes namespace_name = 1;
- getNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
optional bytes namespace_name = 1;
- getNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermissionOrBuilder
-
optional bytes namespace_name = 1;
- getNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
required string namespaceName = 1;
- getNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
required string namespaceName = 1;
- getNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequestOrBuilder
-
required string namespaceName = 1;
- getNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
required string namespaceName = 1;
- getNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
required string namespaceName = 1;
- getNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequestOrBuilder
-
required string namespaceName = 1;
- getNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
required string namespaceName = 1;
- getNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
required string namespaceName = 1;
- getNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequestOrBuilder
-
required string namespaceName = 1;
- getNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
required string namespaceName = 1;
- getNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
required string namespaceName = 1;
- getNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequestOrBuilder
-
required string namespaceName = 1;
- getNamespaceNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
required string namespaceName = 1;
- getNamespaceNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
required string namespaceName = 1;
- getNamespaceNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequestOrBuilder
-
required string namespaceName = 1;
- getNamespaceNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
required string namespaceName = 1;
- getNamespaceNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
required string namespaceName = 1;
- getNamespaceNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequestOrBuilder
-
required string namespaceName = 1;
- getNamespaceNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
required string namespaceName = 1;
- getNamespaceNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
required string namespaceName = 1;
- getNamespaceNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequestOrBuilder
-
required string namespaceName = 1;
- getNamespaceNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
required string namespaceName = 1;
- getNamespaceNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
required string namespaceName = 1;
- getNamespaceNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequestOrBuilder
-
required string namespaceName = 1;
- getNamespacePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .NamespacePermission namespace_permission = 3;
- getNamespacePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
optional .NamespacePermission namespace_permission = 3;
- getNamespacePermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
-
optional .NamespacePermission namespace_permission = 3;
- getNamespacePermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .NamespacePermission namespace_permission = 3;
- getNamespacePermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .NamespacePermission namespace_permission = 3;
- getNamespacePermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
optional .NamespacePermission namespace_permission = 3;
- getNamespacePermissionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
-
optional .NamespacePermission namespace_permission = 3;
- getNamespaceQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getNamespaceQuotaManager() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- getNamespaceRowKey(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getNamespaceRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getNameWithNamespaceInclAsString() - Method in class org.apache.hadoop.hbase.TableName
-
Ideally, getNameAsString should contain namespace within it,
but if the namespace is default, it just returns the name.
- getNbRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
number of results to return
- getNegativeIndex() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getNewAssignmentPlan() - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- getNewByteArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
writing back to byte[]'s
- getNewRpcRetryingCallerFactory(Configuration) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Returns a new RpcRetryingCallerFactory from the given Configuration
.
- getNextBlockOnDiskSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getNextCallSeq() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional uint64 next_call_seq = 6;
- getNextCallSeq() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional uint64 next_call_seq = 6;
- getNextCallSeq() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional uint64 next_call_seq = 6;
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.Filter
-
If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is
the next key it must seek to.
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Filters that are not sure which key must be next seeked to, can inherit
this implementation that, by default, returns a null Cell.
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- getNextCellHint(Cell) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- getNextCellStartPosition() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getNextCellStartPosition() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- getNextIndexedKey() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- getNextIndexedKey() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- getNextIndexedKey() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.Filter
-
Deprecated.
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Deprecated.
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Deprecated.
- getNextKeyHint(KeyValue) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
Deprecated.
- getNextKeyHint(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- getNextMajorCompactTime(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- getNextNodeOffset(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getNextNodeOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNextPath() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Poll for the next path
- getNextPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns the next pointer for the entry in teh LRU.
- getNextQueue() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor.QueueBalancer
-
- getNextRefillTime() - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
-
- getNextRefillTime() - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
-
- getNextRefillTime() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- getNextRowOrNextColumn(byte[], int, int) - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
Retrieve the MatchCode for the next row or column
- getNextRowOrNextColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
- getNextRowOrNextColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
- getNextSequenceId(WAL) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Method to safely get the next sequence number.
- getNextSleepInterval(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
Get how long the caller should sleep according to the current size and
current cycle's total push size and start tick, return the sleep interval
for throttling control.
- getNoChecksumFs() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Returns the filesystem that is specially setup for
doing reads from storage.
- getNode(TokenizerRowSearchResult, byte[], int, int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- getNode(TokenizerRowSearchResult, byte[], int, int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
searching
- getNode(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNode(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNode(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTrackerOrBuilder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.NodeAndData
-
Deprecated.
- getNode() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
- getNodeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTrackerOrBuilder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeDepth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
simple read-only methods
- getNodeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTrackerOrBuilder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the full path node name for the unassigned node for the specified
region.
- getNodeName(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the name of the current node from the specified fully-qualified path.
- getNodeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTrackerOrBuilder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodeOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTrackerOrBuilder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- getNodes(boolean, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- getNonce() - Method in class org.apache.hadoop.hbase.client.Action
-
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional uint64 nonce = 9;
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional uint64 nonce = 9;
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional uint64 nonce = 9;
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequestOrBuilder
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequestOrBuilder
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequestOrBuilder
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
optional uint64 nonce = 3 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
optional uint64 nonce = 3 [default = 0];
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequestOrBuilder
-
optional uint64 nonce = 3 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
optional uint64 nonce = 3 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
optional uint64 nonce = 3 [default = 0];
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequestOrBuilder
-
optional uint64 nonce = 3 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
optional uint64 nonce = 3 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
optional uint64 nonce = 3 [default = 0];
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequestOrBuilder
-
optional uint64 nonce = 3 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequestOrBuilder
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequestOrBuilder
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequestOrBuilder
-
optional uint64 nonce = 4 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
optional uint64 nonce = 3;
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
optional uint64 nonce = 3;
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequestOrBuilder
-
optional uint64 nonce = 3;
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint64 nonce = 14 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional uint64 nonce = 14 [default = 0];
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional uint64 nonce = 14 [default = 0];
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional uint64 nonce = 5;
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
optional uint64 nonce = 5;
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
-
optional uint64 nonce = 5;
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint64 nonce = 10;
- getNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
optional uint64 nonce = 10;
- getNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
optional uint64 nonce = 10;
- getNonce() - Method in class org.apache.hadoop.hbase.util.NonceKey
-
- getNonce() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getNonceGenerator() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- getNonceGenerator() - Method in class org.apache.hadoop.hbase.client.CoprocessorHConnection
-
- getNonceGenerator() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
internal method, do not use thru HConnection
- getNonceGroup() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.client.NonceGenerator
-
- getNonceGroup() - Method in class org.apache.hadoop.hbase.client.PerClientRandomNonceGenerator
-
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
optional uint64 nonceGroup = 2;
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
optional uint64 nonceGroup = 2;
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
-
optional uint64 nonceGroup = 2;
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
optional uint64 nonce_group = 4;
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
optional uint64 nonce_group = 4;
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
-
optional uint64 nonce_group = 4;
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequestOrBuilder
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequestOrBuilder
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequestOrBuilder
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
optional uint64 nonce_group = 2 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
optional uint64 nonce_group = 2 [default = 0];
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequestOrBuilder
-
optional uint64 nonce_group = 2 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
optional uint64 nonce_group = 2 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
optional uint64 nonce_group = 2 [default = 0];
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequestOrBuilder
-
optional uint64 nonce_group = 2 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
optional uint64 nonce_group = 2 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
optional uint64 nonce_group = 2 [default = 0];
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequestOrBuilder
-
optional uint64 nonce_group = 2 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequestOrBuilder
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequestOrBuilder
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequestOrBuilder
-
optional uint64 nonce_group = 3 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
optional uint64 nonce_group = 2;
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
optional uint64 nonce_group = 2;
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequestOrBuilder
-
optional uint64 nonce_group = 2;
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint64 nonce_group = 13 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional uint64 nonce_group = 13 [default = 0];
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional uint64 nonce_group = 13 [default = 0];
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional uint64 nonce_group = 4;
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
optional uint64 nonce_group = 4;
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
-
optional uint64 nonce_group = 4;
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint64 nonceGroup = 9;
- getNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
optional uint64 nonceGroup = 9;
- getNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
optional uint64 nonceGroup = 9;
- getNonceGroup() - Method in class org.apache.hadoop.hbase.util.NonceKey
-
- getNonceGroup() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getNonceKey() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getNonceKey() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getNonceManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getNonceManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Only required for "old" log replay; if it's removed, remove this.
- getNonLeafWriters() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
-
- getNonLeaves() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
-
- getNonLeaves() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
-
- getNoVersionMap() - Method in class org.apache.hadoop.hbase.client.Result
-
Map of families to their most recent qualifiers and values.
- getNumAdded() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
read
- getNumber() - Method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Type
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellType
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Consistency
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Durability
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeUnit
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyState
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableState
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyState
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableState
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableState
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableState
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyState
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableState
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableState
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.State
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureState
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaScope
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaType
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleType
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Type
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.FlushAction
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.EventType
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.ScopeType
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.RecoveryMode
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
-
- getNumber() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
-
- getNumberOfCachedRegionLocations(TableName) - Method in class org.apache.hadoop.hbase.client.MetaCache
-
Return the number of cached region for a table.
- getNumberOfChildren(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the number of children of the specified node.
- getNumberOfListeners() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- getNumberOfOnlineRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getNumberOfRecoveredRegions() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- getNumberOfRegions() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 number_of_requests = 1;
- getNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint64 number_of_requests = 1;
- getNumberOfRequests() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint64 number_of_requests = 1;
- getNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getNumberOfRows() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional uint32 number_of_rows = 4;
- getNumberOfRows() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional uint32 number_of_rows = 4;
- getNumberOfRows() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional uint32 number_of_rows = 4;
- getNumberOfRunningProcess() - Method in class org.apache.hadoop.hbase.util.JVM
-
Workaround to get the current number of process running.
- getNumberOfThreads(JobContext) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
The number of threads in the thread pool that will run the map function.
- getNumBranchNodesIncludingThisNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
count different node types
- getNumBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
-
- getNumBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.row.RowSectionWriter
-
get/set
- getNumBytesCompacted() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
- getNumBytesCompacted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumCells() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getNumChildren() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getNumChunks() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- getNumCompactionsCompleted() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
- getNumCompactionsCompleted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 num_data_index_levels = 8;
- getNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint32 num_data_index_levels = 8;
- getNumDataIndexLevels() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint32 num_data_index_levels = 8;
- getNumDeadRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of dead region servers
- getNumDeadRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getNumExceptions() - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getNumFamilyBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumFilesCompacted() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
- getNumFilesCompacted() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumKeyValueBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumLeafNodesIncludingThisNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getNumLevels() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- getNumLogFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getNumLogFiles(WALFactory) - Static method in class org.apache.hadoop.hbase.wal.BoundedRegionGroupingProvider
-
iff the given WALFactory is using the BoundedRegionGroupingProvider for meta and/or non-meta,
count the number of files (rolled and active).
- getNumLogFiles(WALFactory) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
iff the given WALFactory is using the DefaultWALProvider for meta and/or non-meta,
count the number of files (rolled and active).
- getNumMetaBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumMutationsWithoutWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getNumMutationsWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Number of mutations received with WAL explicitly turned off.
- getNumMutationsWithoutWAL() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getNumMvccVersionBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumNubNodesIncludingThisNode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getNumObservers() - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
-
- getNumOccurrences() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getNumOnlineRegions() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
The number of online regions
- getNumOpenConnections() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getNumOpenConnections() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getNumPositivesForTesting(int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- getNumQualifierBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumQueriesForTesting(int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- getNumRegions() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- getNumRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the number of live region servers
- getNumRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getNumRegionsOpened() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Used by unit tests.
- getNumRolledLogFiles() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getNumRolledLogFiles(WAL) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
returns the number of rolled WAL files.
- getNumRootEntries() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- getNumRowBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
number of rows to return
- getNumRows() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
number of rows to return
- getNumStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of store files hosted on this region server.
- getNumStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the number of store files hosted on this region server.
- getNumStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumStores() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of stores hosted on this region server.
- getNumStores() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the number of stores hosted on this region server.
- getNumStores() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getNumTagsBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumThreads() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getNumThreads() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
- getNumThreads() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- getNumTimestampBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumUniqueFamilies() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumUniqueQualifiers() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumUniqueRows() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumUniqueTags() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumUniqueValues() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
- getNumValueBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getNumVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
number of versions to retrieve
- getNumVersions() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
number of versions to retrieve
- getNumWALFiles() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of WAL files of this region server.
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- getObjectFromMessage(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getObjectFromMessage(byte[]) - Method in interface org.apache.hadoop.hbase.rest.ProtobufMessageHandler
-
Initialize the model from a protobuf representation.
- getOffline() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bool offline = 5;
- getOffline() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
optional bool offline = 5;
- getOffline() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
optional bool offline = 5;
- getOffPeakHours() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getOffset() - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
-
- getOffset() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- getOffset() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getOffset() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getOffset() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- getOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
optional int32 offset = 2;
- getOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
optional int32 offset = 2;
- getOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
-
optional int32 offset = 2;
- getOffset() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
- getOffset() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getOffset() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
The offset, the index into the underlying byte[] at which this range
begins.
- getOldestHfileTs(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getOldestHfileTs(boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
This can be used to determine the last time all files of this region were major compacted.
- getOldestSeqIdOfStore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getOldestSeqIdOfStore(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getOldLogDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Get the directory where old logs go
- getOldLogDir() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get the directory where wals are archived
- getOldSources() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a list of all the old sources of this rs
- getOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
required bool on = 1;
- getOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
required bool on = 1;
- getOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequestOrBuilder
-
required bool on = 1;
- getOnDiskSizeWithHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getOnDiskSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
-
- getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest, RpcCallback<AdminProtos.GetOnlineRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
rpc GetOnlineRegion(.GetOnlineRegionRequest) returns (.GetOnlineRegionResponse);
- getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest, RpcCallback<AdminProtos.GetOnlineRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
-
rpc GetOnlineRegion(.GetOnlineRegionRequest) returns (.GetOnlineRegionResponse);
- getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest, RpcCallback<AdminProtos.GetOnlineRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
-
- getOnlineRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getOnlineRegion(RpcController, AdminProtos.GetOnlineRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getOnlineRegions(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get all the online regions on a region server.
- getOnlineRegions(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get all the online regions on a region server.
- getOnlineRegions(AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to get the all the online regions on a region
server using admin protocol.
- getOnlineRegions(RpcController, AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to get the all the online regions on a region
server using admin protocol.
- getOnlineRegions(TableName) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Gets the online regions of the specified table.
- getOnlineRegions(TableName) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
Get all online regions of a table in this RS.
- getOnlineRegions() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
-
- getOnlineRegionsLocalContext() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
For tests, web ui and metrics.
- getOnlineServers() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getOnlineServers() - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
-
Gets the online servers.
- getOnlineServersList() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- getOnlineTables() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Gets the online tables in this RS.
- getOnlineTables() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getOnlyType() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
-
- getOpenFileDescriptorCount() - Method in class org.apache.hadoop.hbase.util.JVM
-
Get the number of opened filed descriptor for the runtime jvm.
- getOpenForDistributedLogReplay() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
optional bool openForDistributedLogReplay = 4;
- getOpenForDistributedLogReplay() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
optional bool openForDistributedLogReplay = 4;
- getOpenForDistributedLogReplay() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
-
optional bool openForDistributedLogReplay = 4;
- getOpenInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfo(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpenInfoOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- getOpeningState(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- getOpeningState(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- getOpeningState(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponseOrBuilder
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- getOpeningStateCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- getOpeningStateCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- getOpeningStateCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponseOrBuilder
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- getOpeningStateList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- getOpeningStateList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- getOpeningStateList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponseOrBuilder
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- getOpenRegionCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
Method to retrieve coordination for opening region operations.
- getOpenRegionCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getOpenSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
optional uint64 open_seq_num = 3;
- getOpenSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
optional uint64 open_seq_num = 3;
- getOpenSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransitionOrBuilder
-
optional uint64 open_seq_num = 3;
- getOpenSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getOpenSeqNum() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getOpenSeqNum() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.RegionStateTransitionContext
-
- getOperation(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getOperationSize(OperationQuota.OperationType) - Method in class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- getOperationStatus(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getOperationStatusCode() - Method in class org.apache.hadoop.hbase.regionserver.OperationStatus
-
- getOperationTimeout() - Method in interface org.apache.hadoop.hbase.client.Admin
-
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getOperator() - Method in class org.apache.hadoop.hbase.filter.BitComparator
-
- getOperator() - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- getOperator() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Get the operator.
- getOperator() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getOperator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
required .FilterList.Operator operator = 1;
- getOperator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
required .FilterList.Operator operator = 1;
- getOperator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
-
required .FilterList.Operator operator = 1;
- getOperator() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- getOrder() - Method in interface org.apache.hadoop.hbase.types.DataType
-
Retrieve the sort
Order
imposed by this data type, or null when
natural ordering is not preserved.
- getOrder() - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.PBType
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawByte
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawLong
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawShort
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.RawString
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Struct
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union2
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union3
-
- getOrder() - Method in class org.apache.hadoop.hbase.types.Union4
-
- getOrdinal() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
optional uint32 ordinal = 2;
- getOrdinal() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
optional uint32 ordinal = 2;
- getOrdinal() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelOrBuilder
-
optional uint32 ordinal = 2;
- getOriginalIndex() - Method in class org.apache.hadoop.hbase.client.Action
-
- getOriginatingClusterId() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getOriginPath() - Method in class org.apache.hadoop.hbase.io.HFileLink
-
- getOrigLogSeqNum() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
Return a positive long if current WALKey is created from a replay edit
- getOrigSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint64 orig_sequence_number = 11;
- getOrigSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
optional uint64 orig_sequence_number = 11;
- getOrigSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
optional uint64 orig_sequence_number = 11;
- getOSVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string osVersion = 3;
- getOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string osVersion = 3;
- getOsVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string osVersion = 3;
- getOsVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string osVersion = 3;
- getOsVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string osVersion = 3;
- getOsVersionBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string osVersion = 3;
- getOuputStream() - Method in class org.apache.hadoop.hbase.codec.BaseEncoder
-
- getOutputArrayLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
- getOutputArrayOffset(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnSectionWriter
-
- getOutputArrayOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Returns the output committer.
- getOutputCounts() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- getOutputStream() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- getOutputStream(OutputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Get a SASL wrapped OutputStream.
- getOverallAverageLatency() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getOverlapGroups(TableName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getOwner() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional string owner = 6;
- getOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
optional string owner = 6;
- getOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
optional string owner = 6;
- getOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional string owner = 5;
- getOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional string owner = 5;
- getOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional string owner = 5;
- getOwnerBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional string owner = 6;
- getOwnerBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
optional string owner = 6;
- getOwnerBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
optional string owner = 6;
- getOwnerBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional string owner = 5;
- getOwnerBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional string owner = 5;
- getOwnerBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional string owner = 5;
- getOwnerString() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getPaddedTokenAndOccurrenceString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getPageSize() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- getPageSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
-
required int64 page_size = 1;
- getPageSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
required int64 page_size = 1;
- getPageSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilterOrBuilder
-
required int64 page_size = 1;
- getParameter(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
Unquote the name and quote the value.
- getParameterMap() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
- getParameterNames() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
Return the set of parameter names, quoting each name.
- getParameterValues(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
- getParams() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getParent() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getParent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Returns the full path of the immediate parent of the specified node.
- getParentId() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint64 parent_id = 2;
- getParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional uint64 parent_id = 2;
- getParentId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional uint64 parent_id = 2;
- getParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
optional int64 parent_id = 2;
- getParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
optional int64 parent_id = 2;
- getParentId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfoOrBuilder
-
optional int64 parent_id = 2;
- getParentProcId() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getParentStartPosition() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
-
- getParsedGenericInstance(Class<?>, int, ByteString) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Get an instance of the argument type declared in a class's signature.
- getParserForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
- getParserForType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getParserForType() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional bool partial = 5 [default = false];
- getPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
optional bool partial = 5 [default = false];
- getPartial() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
optional bool partial = 5 [default = false];
- getPartialFlagPerResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated bool partial_flag_per_result = 7;
- getPartialFlagPerResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
repeated bool partial_flag_per_result = 7;
- getPartialFlagPerResult(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
repeated bool partial_flag_per_result = 7;
- getPartialFlagPerResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated bool partial_flag_per_result = 7;
- getPartialFlagPerResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
repeated bool partial_flag_per_result = 7;
- getPartialFlagPerResultCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
repeated bool partial_flag_per_result = 7;
- getPartialFlagPerResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated bool partial_flag_per_result = 7;
- getPartialFlagPerResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
repeated bool partial_flag_per_result = 7;
- getPartialFlagPerResultList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
repeated bool partial_flag_per_result = 7;
- getPartition(ImmutableBytesWritable, V2, int) - Method in class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
- getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Gets the partition number for a given key (hence record) given the total
number of partitions i.e.
- getPartition(ImmutableBytesWritable, VALUE, int) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- getPassword(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Get the password from the Configuration instance using the
getPassword method if it exists.
- getPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
optional bytes password = 2;
- getPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
optional bytes password = 2;
- getPassword() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
-
optional bytes password = 2;
- getPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional bytes password = 2;
- getPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
optional bytes password = 2;
- getPassword() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
-
optional bytes password = 2;
- getPath() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getPath() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- getPath() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getPath() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
- getPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
required string path = 2;
- getPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
required string path = 2;
- getPath() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder
-
required string path = 2;
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- getPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getPath(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Return the 'path' component of a Path.
- getPath() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.AcquiredLock
-
- getPath(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
- getPath() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- getPathBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
required string path = 2;
- getPathBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
required string path = 2;
- getPathBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder
-
required string path = 2;
- getPattern() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required string pattern = 1;
- getPattern() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
required string pattern = 1;
- getPattern() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
-
required string pattern = 1;
- getPatternBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required string pattern = 1;
- getPatternBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
required string pattern = 1;
- getPatternBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
-
required string pattern = 1;
- getPatternFlags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required int32 pattern_flags = 2;
- getPatternFlags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
required int32 pattern_flags = 2;
- getPatternFlags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
-
required int32 pattern_flags = 2;
- getPauseTime(long, int) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Calculate pause time.
- getPayload() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
optional bytes payload = 5;
- getPayload() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
optional bytes payload = 5;
- getPayload() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
-
optional bytes payload = 5;
- getPayload() - Method in class org.apache.hadoop.hbase.RegionTransition
-
- getPeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Returns the ReplicationPeer
- getPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getPeerClusterId() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getPeerClusterId() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get the id that the source is replicating to.
- getPeerClusterZnode() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getPeerClusterZnode() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get the id that the source is replicating to
- getPeerClusterZnode() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- getPeerConf(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Returns the configuration needed to talk to the remote slave cluster.
- getPeerConf(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getPeerConfig(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getPeerConfig() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get the peer config object
- getPeerConfig() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
Get the peer config object
- getPeerData() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getPeerID() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required string peerID = 1;
- getPeerID() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
required string peerID = 1;
- getPeerID() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
-
required string peerID = 1;
- getPeerID() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get the slave peer ID
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getPeerID() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getPeerId() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueueInfo
-
- getPeerIDBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required string peerID = 1;
- getPeerIDBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
required string peerID = 1;
- getPeerIDBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
-
required string peerID = 1;
- getPeerIds() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Returns the set of peerIds defined
- getPeerIds() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getPeersCount() - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Get the number of slave clusters the local cluster has.
- getPeerState(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Get the state of the specified peer cluster
- getPeerState() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Returns the state of the peer
- getPeerState() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
- getPeerTableCFs(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Get the replicable table-cf config of the specified peer.
- getPeerTableCFsConfig(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Get the table and column-family list string of the peer from ZK.
- getPeerTableCFsConfig(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getPeerUUID() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- getPeerUUID() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Returns a UUID of the provided peer id.
- getPeerUUID() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- getPercentFileLocal() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the percent of HFiles' that are local.
- getPercentFileLocalSecondaryRegions() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the percent of HFiles' that are local for secondary region replicas.
- getPeriod() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getPeriod() - Method in class org.apache.hadoop.hbase.util.Sleeper
-
- getPermission(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- getPermission(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
repeated .Permission permission = 1;
- getPermission(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequestOrBuilder
-
repeated .Permission permission = 1;
- getPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
required .Permission permission = 3;
- getPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
required .Permission permission = 3;
- getPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionOrBuilder
-
required .Permission permission = 3;
- getPermissionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- getPermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
required .Permission permission = 3;
- getPermissionBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- getPermissionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- getPermissionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
repeated .Permission permission = 1;
- getPermissionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequestOrBuilder
-
repeated .Permission permission = 1;
- getPermissionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- getPermissionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
repeated .Permission permission = 1;
- getPermissionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequestOrBuilder
-
repeated .Permission permission = 1;
- getPermissionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- getPermissionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
repeated .Permission permission = 1;
- getPermissionOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequestOrBuilder
-
repeated .Permission permission = 1;
- getPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
required .Permission permission = 3;
- getPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
required .Permission permission = 3;
- getPermissionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionOrBuilder
-
required .Permission permission = 3;
- getPermissionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- getPermissionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
repeated .Permission permission = 1;
- getPermissionOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequestOrBuilder
-
repeated .Permission permission = 1;
- getPermissions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- getPermissions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
repeated .Permission permissions = 2;
- getPermissions(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissionsOrBuilder
-
repeated .Permission permissions = 2;
- getPermissionsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- getPermissionsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- getPermissionsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- getPermissionsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
repeated .Permission permissions = 2;
- getPermissionsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissionsOrBuilder
-
repeated .Permission permissions = 2;
- getPermissionsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- getPermissionsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
repeated .Permission permissions = 2;
- getPermissionsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissionsOrBuilder
-
repeated .Permission permissions = 2;
- getPermissionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- getPermissionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
repeated .Permission permissions = 2;
- getPermissionsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissionsOrBuilder
-
repeated .Permission permissions = 2;
- getPermissionsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- getPermissionsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
repeated .Permission permissions = 2;
- getPermissionsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissionsOrBuilder
-
repeated .Permission permissions = 2;
- getPhase() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.JournalEntry
-
- getPhase() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl.JournalEntryImpl
-
- getPhase() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction.JournalEntry
-
- getPhase() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
-
- getPool() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getPool() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getPoolCompletedTaskCount() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getPoolCompletedTaskCount() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getPoolLargestPoolSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getPoolLargestPoolSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getPoolSize(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- getPoolTaskCount() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getPoolTaskCount() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getPoolType(Configuration) - Static method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- getPort() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getPort() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getPort() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- getPort() - Method in class org.apache.hadoop.hbase.http.InfoServer
-
Deprecated.
- getPort() - Method in exception org.apache.hadoop.hbase.ipc.RemoteWithExtrasException
-
- getPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
optional uint32 port = 2;
- getPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
optional uint32 port = 2;
- getPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
-
optional uint32 port = 2;
- getPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
required uint32 port = 1;
- getPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
required uint32 port = 1;
- getPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
-
required uint32 port = 1;
- getPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional int32 port = 4;
- getPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional int32 port = 4;
- getPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional int32 port = 4;
- getPort() - Method in class org.apache.hadoop.hbase.ServerName
-
- getPort() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- getPos() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- getPos() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- getPosition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
-
required int64 position = 1;
- getPosition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
required int64 position = 1;
- getPosition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPositionOrBuilder
-
required int64 position = 1;
- getPosition() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getPosition() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- getPosition() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationWALReaderManager
-
Get the position that we stopped reading at
- getPosition() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getPosition() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
The current position
marker.
- getPosition() - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
-
- getPreAssignedWriteNumber(AtomicLong) - Static method in class org.apache.hadoop.hbase.regionserver.MultiVersionConsistencyControl
-
Get a mvcc write number before an actual one(its log sequence Id) being assigned
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
-
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- getPrefix() - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
-
- getPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
-
required bytes prefix = 1;
- getPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
required bytes prefix = 1;
- getPrefix() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilterOrBuilder
-
required bytes prefix = 1;
- getPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
-
optional bytes prefix = 1;
- getPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
optional bytes prefix = 1;
- getPrefix() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilterOrBuilder
-
optional bytes prefix = 1;
- getPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
required bool preserve_splits = 2;
- getPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
required bool preserve_splits = 2;
- getPreserveSplits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
required bool preserve_splits = 2;
- getPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
optional bool preserveSplits = 2 [default = false];
- getPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
optional bool preserveSplits = 2 [default = false];
- getPreserveSplits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequestOrBuilder
-
optional bool preserveSplits = 2 [default = false];
- getPrevBalanceValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
-
optional bool prev_balance_value = 1;
- getPrevBalanceValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
optional bool prev_balance_value = 1;
- getPrevBalanceValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponseOrBuilder
-
optional bool prev_balance_value = 1;
- getPrevBlockOffset() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getPrevPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns the previous pointer for the entry in the LRU.
- getPrevValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
-
optional bool prev_value = 1;
- getPrevValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
optional bool prev_value = 1;
- getPrevValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponseOrBuilder
-
optional bool prev_value = 1;
- getPrimaryCallTimeoutMicroSecond() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getPrimaryHRIForDeployedReplica() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getPrimaryOperationTimeout() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getPrincipalWithoutRealm(String) - Static method in class org.apache.hadoop.hbase.security.SecurityUtil
-
Get the user name from a principal
- getPriority() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getPriority() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getPriority() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Get the priority level for this handler instance.
- getPriority() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- getPriority() - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
-
- getPriority() - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- getPriority(RPCProtos.RequestHeader, Message) - Method in interface org.apache.hadoop.hbase.ipc.PriorityFunction
-
Returns the 'priority type' of the specified request.
- getPriority() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getPriority() - Method in class org.apache.hadoop.hbase.master.handler.ClosedRegionHandler
-
- getPriority() - Method in class org.apache.hadoop.hbase.master.handler.OpenedRegionHandler
-
- getPriority() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureFairRunQueues.FairObject
-
- getPriority() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional uint32 priority = 6;
- getPriority() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional uint32 priority = 6;
- getPriority() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional uint32 priority = 6;
- getPriority() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Gets the priority for the request
- getPriority() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getPriority(RPCProtos.RequestHeader, Message) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getPriorityQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the priority queue for metrics.
- getPriorityQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getProcedure(String) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Returns the procedure.
- getProcedure(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
required .ProcedureDescription procedure = 1;
- getProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
required .ProcedureDescription procedure = 1;
- getProcedure() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequestOrBuilder
-
required .ProcedureDescription procedure = 1;
- getProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
optional .ProcedureDescription procedure = 1;
- getProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
optional .ProcedureDescription procedure = 1;
- getProcedure() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequestOrBuilder
-
optional .ProcedureDescription procedure = 1;
- getProcedure(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- getProcedure(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
repeated .Procedure procedure = 1;
- getProcedure(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponseOrBuilder
-
repeated .Procedure procedure = 1;
- getProcedure(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- getProcedure(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
repeated .Procedure procedure = 2;
- getProcedure(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntryOrBuilder
-
repeated .Procedure procedure = 2;
- getProcedureBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
required .ProcedureDescription procedure = 1;
- getProcedureBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
optional .ProcedureDescription procedure = 1;
- getProcedureBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- getProcedureBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- getProcedureBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- getProcedureBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- getProcedureCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- getProcedureCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
repeated .Procedure procedure = 1;
- getProcedureCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponseOrBuilder
-
repeated .Procedure procedure = 1;
- getProcedureCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- getProcedureCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
repeated .Procedure procedure = 2;
- getProcedureCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntryOrBuilder
-
repeated .Procedure procedure = 2;
- getProcedureList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- getProcedureList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
repeated .Procedure procedure = 1;
- getProcedureList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponseOrBuilder
-
repeated .Procedure procedure = 1;
- getProcedureList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- getProcedureList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
repeated .Procedure procedure = 2;
- getProcedureList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntryOrBuilder
-
repeated .Procedure procedure = 2;
- getProcedureManager(String) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
-
- getProcedureManagers() - Method in class org.apache.hadoop.hbase.procedure.ProcedureManagerHost
-
- getProcedureNames() - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
- getProcedureOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
required .ProcedureDescription procedure = 1;
- getProcedureOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
required .ProcedureDescription procedure = 1;
- getProcedureOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequestOrBuilder
-
required .ProcedureDescription procedure = 1;
- getProcedureOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
optional .ProcedureDescription procedure = 1;
- getProcedureOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
optional .ProcedureDescription procedure = 1;
- getProcedureOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequestOrBuilder
-
optional .ProcedureDescription procedure = 1;
- getProcedureOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- getProcedureOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
repeated .Procedure procedure = 1;
- getProcedureOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponseOrBuilder
-
repeated .Procedure procedure = 1;
- getProcedureOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- getProcedureOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
repeated .Procedure procedure = 2;
- getProcedureOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntryOrBuilder
-
repeated .Procedure procedure = 2;
- getProcedureOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- getProcedureOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
repeated .Procedure procedure = 1;
- getProcedureOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponseOrBuilder
-
repeated .Procedure procedure = 1;
- getProcedureOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- getProcedureOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
repeated .Procedure procedure = 2;
- getProcedureOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntryOrBuilder
-
repeated .Procedure procedure = 2;
- getProcedureQueue() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getProcedureResult(MasterProtos.GetProcedureResultRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- getProcedureResult(RpcController, MasterProtos.GetProcedureResultRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getProcedureResult(RpcController, MasterProtos.GetProcedureResultRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- getProcedureResult(RpcController, MasterProtos.GetProcedureResultRequest, RpcCallback<MasterProtos.GetProcedureResultResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc getProcedureResult(.GetProcedureResultRequest) returns (.GetProcedureResultResponse);
- getProcedureResult(RpcController, MasterProtos.GetProcedureResultRequest, RpcCallback<MasterProtos.GetProcedureResultResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc getProcedureResult(.GetProcedureResultRequest) returns (.GetProcedureResultResponse);
- getProcedureResult(RpcController, MasterProtos.GetProcedureResultRequest, RpcCallback<MasterProtos.GetProcedureResultResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- getProcedures() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFormatReader
-
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.procedure.ProcedureManager
-
Return the unique signature of the procedure.
- getProcedureSignature() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
- getProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
optional bool processed = 2;
- getProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
optional bool processed = 2;
- getProcessed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
-
optional bool processed = 2;
- getProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
optional bool processed = 2;
- getProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
optional bool processed = 2;
- getProcessed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponseOrBuilder
-
optional bool processed = 2;
- getProcessName() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getProcessName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getProcId() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getProcId() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
required uint64 proc_id = 1;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
required uint64 proc_id = 1;
- getProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequestOrBuilder
-
required uint64 proc_id = 1;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
-
optional uint64 proc_id = 1;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
optional uint64 proc_id = 1;
- getProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponseOrBuilder
-
optional uint64 proc_id = 1;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
-
optional uint64 proc_id = 1;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
optional uint64 proc_id = 1;
- getProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponseOrBuilder
-
optional uint64 proc_id = 1;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
-
optional uint64 proc_id = 1;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
optional uint64 proc_id = 1;
- getProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponseOrBuilder
-
optional uint64 proc_id = 1;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
-
optional uint64 proc_id = 1;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
optional uint64 proc_id = 1;
- getProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponseOrBuilder
-
optional uint64 proc_id = 1;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
-
required uint64 proc_id = 1;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
required uint64 proc_id = 1;
- getProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequestOrBuilder
-
required uint64 proc_id = 1;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required uint64 proc_id = 3;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
required uint64 proc_id = 3;
- getProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
required uint64 proc_id = 3;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
optional uint64 proc_id = 3;
- getProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
optional uint64 proc_id = 3;
- getProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntryOrBuilder
-
optional uint64 proc_id = 3;
- getProcName() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getProcOwner() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getProcState() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
The current progress of the record reader through its data.
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
The current progress of the record reader through its data.
- getProgress() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- getProgress() - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- getProgressPct() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
getter for calculated percent complete
- getPromotedValueFromProto(HBaseProtos.BigDecimalMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getPromotedValueFromProto(HBaseProtos.DoubleMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getPromotedValueFromProto(HBaseProtos.LongMsg) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getPromotedValueFromProto(R) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the promoted type from the proto message
- getProtobuf(UriInfo, String, String, int, String, String, List<String>, int, int, long, long, boolean) - Method in class org.apache.hadoop.hbase.rest.TableScanResource
-
- getProtocol() - Method in exception org.apache.hadoop.hbase.exceptions.UnknownProtocolException
-
- getProtoForCellType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getProtoForCellType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getProtoForCellType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getProtoForCellType(T) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the PB message corresponding to the cell type
- getProtoForPromotedType(BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getProtoForPromotedType(Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getProtoForPromotedType(Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getProtoForPromotedType(S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method gets the PB message corresponding to the promoted type
- getProvider() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Return the provider for this Cipher
- getPurpose() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional string purpose = 5;
- getPurpose() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional string purpose = 5;
- getPurpose() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional string purpose = 5;
- getPurposeBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional string purpose = 5;
- getPurposeBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional string purpose = 5;
- getPurposeBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional string purpose = 5;
- getPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
the TPut to put if the check succeeds
- getPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
the TPut to put
- getPut() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- getPuts() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
a list of TPuts to commit
- getPutsIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- getPutsSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- getQop(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
-
- getQualifiedPath() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getQualifier() - Method in interface org.apache.hadoop.hbase.Cell
-
- getQualifier() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- getQualifier() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- getQualifier() - Method in class org.apache.hadoop.hbase.KeyValue
-
Deprecated.
- getQualifier(int) - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional bytes qualifier = 3;
- getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
optional bytes qualifier = 3;
- getQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
-
optional bytes qualifier = 3;
- getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes qualifier = 3;
- getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional bytes qualifier = 3;
- getQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional bytes qualifier = 3;
- getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
required bytes qualifier = 3;
- getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
required bytes qualifier = 3;
- getQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
required bytes qualifier = 3;
- getQualifier(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
repeated bytes qualifier = 2;
- getQualifier(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
repeated bytes qualifier = 2;
- getQualifier(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ColumnOrBuilder
-
repeated bytes qualifier = 2;
- getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required bytes qualifier = 3;
- getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
required bytes qualifier = 3;
- getQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
-
required bytes qualifier = 3;
- getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional bytes qualifier = 1;
- getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
optional bytes qualifier = 1;
- getQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
-
optional bytes qualifier = 1;
- getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
required bytes qualifier = 2;
- getQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
required bytes qualifier = 2;
- getQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableNameOrBuilder
-
required bytes qualifier = 2;
- getQualifier() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getQualifier() - Method in class org.apache.hadoop.hbase.TableName
-
- getQualifier() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
Deprecated.
- getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
column qualifier to check
- getQualifier() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
column qualifier to check
- getQualifierArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getQualifierArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getQualifierArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getQualifierAsString() - Method in class org.apache.hadoop.hbase.TableName
-
- getQualifierBufferLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- getQualifierBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getQualifierCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
repeated bytes qualifier = 2;
- getQualifierCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
repeated bytes qualifier = 2;
- getQualifierCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ColumnOrBuilder
-
repeated bytes qualifier = 2;
- getQualifierLength() - Method in interface org.apache.hadoop.hbase.Cell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getQualifierLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getQualifierList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
repeated bytes qualifier = 2;
- getQualifierList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
repeated bytes qualifier = 2;
- getQualifierList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ColumnOrBuilder
-
repeated bytes qualifier = 2;
- getQualifierOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getQualifierOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getQualifierOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getQualifiers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
repeated bytes qualifiers = 1;
- getQualifiers(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
repeated bytes qualifiers = 1;
- getQualifiers(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilterOrBuilder
-
repeated bytes qualifiers = 1;
- getQualifiersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
repeated bytes qualifiers = 1;
- getQualifiersCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
repeated bytes qualifiers = 1;
- getQualifiersCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilterOrBuilder
-
repeated bytes qualifiers = 1;
- getQualifiersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
repeated bytes qualifiers = 1;
- getQualifiersList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
repeated bytes qualifiers = 1;
- getQualifiersList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilterOrBuilder
-
repeated bytes qualifiers = 1;
- getQualifierSorter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getQualifierString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- getQualifierValue(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValue(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValue(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierValueOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- getQualifierWriter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getQuantile(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
- getQuarantined() - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- getQueueLength() - Method in class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
-
- getQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Returns the length of the pending queue
- getQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getQueues() - Method in class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
-
- getQueues() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Returns the list of request queues
- getQueues() - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- getQueueSize() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getQueueSize() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getQueuesZNodeCversion() - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueuesClient
-
Get the cversion of replication rs node.
- getQueuesZNodeCversion() - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesClientZKImpl
-
- getQuorum() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Get the quorum address of this instance.
- getQuota(UserGroupInformation, TableName) - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
Returns the quota for an operation.
- getQuotaRetriever(QuotaFilter) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Return a QuotaRetriever to list the quotas based on the filter.
- getQuotaRetriever(QuotaFilter) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Return a Quota Scanner to list the quotas based on the filter.
- getQuotaType() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getRack(ServerName) - Method in class org.apache.hadoop.hbase.master.RackManager
-
Get the name of the rack containing a server, according to the DNS to
switch mapping.
- getRack(List<ServerName>) - Method in class org.apache.hadoop.hbase.master.RackManager
-
- getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- getRandomKey() - Method in class org.apache.hadoop.hbase.io.crypto.Cipher
-
Create a random symmetric key
- getRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
required .Reference.Range range = 2;
- getRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
required .Reference.Range range = 2;
- getRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.ReferenceOrBuilder
-
required .Reference.Range range = 2;
- getRange() - Method in class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
-
Returns the ranges to be counted
- getRange() - Method in class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
-
- getRange() - Method in class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
-
- getRangeType() - Method in class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
-
Returns the type of range histogram size or time
- getRangeType() - Method in class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
-
- getRangeType() - Method in class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
-
- getRangeVals() - Method in class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
-
Returns the range counts
- getRangeVals() - Method in class org.apache.hadoop.metrics2.lib.MutableSizeHistogram
-
- getRangeVals() - Method in class org.apache.hadoop.metrics2.lib.MutableTimeHistogram
-
- getRaw(String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- getReachedBarrierNode(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getReachedBarrierNode(ZKProcedureUtil, String) - Static method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
Get the full znode path for the node used by the coordinator to trigger a global barrier
execution and release on each subprocedure.
- getReadAvailable() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- getReadAvailable() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
- getReadAvailable() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
- getReadAvailable() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- getReader() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- getReader() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- getReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getReader() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
-
- getReader(FileStatus, boolean, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Create a new
WAL.Reader
for reading logs to split.
- getReader(Path, CancelableProgressable) - Method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Create a new
WAL.Reader
for reading logs to split.
- getReadNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_num = 5;
- getReadNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota read_num = 5;
- getReadNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota read_num = 5;
- getReadNumBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_num = 5;
- getReadNumOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_num = 5;
- getReadNumOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota read_num = 5;
- getReadNumOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota read_num = 5;
- getReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional bool readOnly = 5;
- getReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
optional bool readOnly = 5;
- getReadOnly() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
optional bool readOnly = 5;
- getReadpoint(IsolationLevel) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getReadpoint(IsolationLevel) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getReadRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the total number of read requests that have been issued against this region
- getReadRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 read_requests_count = 8;
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint64 read_requests_count = 8;
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint64 read_requests_count = 8;
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of read requests to regions hosted on this region server.
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 readRequestsCount = 7;
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int64 readRequestsCount = 7;
- getReadRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int64 readRequestsCount = 7;
- getReadRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getReadSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_size = 6;
- getReadSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota read_size = 6;
- getReadSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota read_size = 6;
- getReadSizeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_size = 6;
- getReadSizeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_size = 6;
- getReadSizeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota read_size = 6;
- getReadSizeOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota read_size = 6;
- getRealCacheSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getRealUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
optional string real_user = 2;
- getRealUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
optional string real_user = 2;
- getRealUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformationOrBuilder
-
optional string real_user = 2;
- getRealUserBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
optional string real_user = 2;
- getRealUserBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
optional string real_user = 2;
- getRealUserBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformationOrBuilder
-
optional string real_user = 2;
- getReason() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
required string reason = 1;
- getReason() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
required string reason = 1;
- getReason() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequestOrBuilder
-
required string reason = 1;
- getReason() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getReasonBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
required string reason = 1;
- getReasonBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
required string reason = 1;
- getReasonBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequestOrBuilder
-
required string reason = 1;
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Builds a TableRecordReader.
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.hadoop.hbase.mapred.TableOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
-
Deprecated.
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableOutputFormat
-
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
Creates a new record writer.
- getRecoverableZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Get the connection to ZooKeeper.
- getRecoveringRegions() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRecoveringRegions() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getRecoveryMode() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Temporary function, mostly for UTs.
- getRecoveryMode() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- getRecoveryMode() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- getReference() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
optional .Reference reference = 2;
- getReference() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
optional .Reference reference = 2;
- getReference() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFileOrBuilder
-
optional .Reference reference = 2;
- getReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getReferenceBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
optional .Reference reference = 2;
- getReferencedFileStatus(FileSystem) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Get the FileStatus
of the file referenced by this StoreFileInfo
- getReferencedHFileName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the HFile name of the referenced link
- getReferencedRegionName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the Region name of the referenced link
- getReferencedTableName(String) - Static method in class org.apache.hadoop.hbase.io.HFileLink
-
Get the Table name of the referenced link
- getReferenceFilePaths(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getReferenceOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
optional .Reference reference = 2;
- getReferenceOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
optional .Reference reference = 2;
- getReferenceOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFileOrBuilder
-
optional .Reference reference = 2;
- getReferredToFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- getRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional string regex = 2;
- getRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
optional string regex = 2;
- getRegex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
optional string regex = 2;
- getRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional string regex = 1;
- getRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
optional string regex = 1;
- getRegex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequestOrBuilder
-
optional string regex = 1;
- getRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
optional string regex = 1;
- getRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
optional string regex = 1;
- getRegex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequestOrBuilder
-
optional string regex = 1;
- getRegexBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional string regex = 2;
- getRegexBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
optional string regex = 2;
- getRegexBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
optional string regex = 2;
- getRegexBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional string regex = 1;
- getRegexBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
optional string regex = 1;
- getRegexBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequestOrBuilder
-
optional string regex = 1;
- getRegexBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
optional string regex = 1;
- getRegexBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
optional string regex = 1;
- getRegexBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequestOrBuilder
-
optional string regex = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getRegion() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
- getRegion() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getRegion(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
required .RegionInfo region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
required .RegionInfo region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
-
required .RegionInfo region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
required .RegionInfo region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
required .RegionInfo region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfoOrBuilder
-
required .RegionInfo region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .RegionInfo region = 4;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
optional .RegionInfo region = 4;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplitOrBuilder
-
optional .RegionInfo region = 4;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
required .RegionSpecifier region = 1;
- getRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegion(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Protected utility method for safely obtaining an HRegion handle.
- getRegion() - Method in class org.apache.hadoop.hbase.regionserver.RegionServerServices.PostOpenDeployContext
-
- getRegion(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getRegion() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- getRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
required .RegionSpecifier region_a = 1;
- getRegionA() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
-
required .RegionSpecifier region_a = 1;
- getRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- getRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
required .RegionSpecifier region_a = 1;
- getRegionA() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequestOrBuilder
-
required .RegionSpecifier region_a = 1;
- getRegionABuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- getRegionABuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- getRegionAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- getRegionAction(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
repeated .RegionAction regionAction = 1;
- getRegionAction(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
-
repeated .RegionAction regionAction = 1;
- getRegionActionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- getRegionActionBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- getRegionActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- getRegionActionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
repeated .RegionAction regionAction = 1;
- getRegionActionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
-
repeated .RegionAction regionAction = 1;
- getRegionActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- getRegionActionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
repeated .RegionAction regionAction = 1;
- getRegionActionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
-
repeated .RegionAction regionAction = 1;
- getRegionActionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- getRegionActionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
repeated .RegionAction regionAction = 1;
- getRegionActionOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
-
repeated .RegionAction regionAction = 1;
- getRegionActionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- getRegionActionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
repeated .RegionAction regionAction = 1;
- getRegionActionOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
-
repeated .RegionAction regionAction = 1;
- getRegionActionResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResult(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionActionResultOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
-
repeated .RegionActionResult regionActionResult = 1;
- getRegionAOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- getRegionAOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
required .RegionSpecifier region_a = 1;
- getRegionAOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
-
required .RegionSpecifier region_a = 1;
- getRegionAOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- getRegionAOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
required .RegionSpecifier region_a = 1;
- getRegionAOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequestOrBuilder
-
required .RegionSpecifier region_a = 1;
- getRegionArchiveDir(Path, TableName, Path) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the archive directory for a given region under the specified table
- getRegionArchiveDir(Path, TableName, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the archive directory for a given region under the specified table
- getRegionAssignments() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- getRegionAssignmentsByServer(Collection<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- getRegionAssignmentsByServer() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Returns a clone of region assignments per server
- getRegionAssignmentSnapshot() - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- getRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- getRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
required .RegionSpecifier region_b = 2;
- getRegionB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
-
required .RegionSpecifier region_b = 2;
- getRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- getRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
required .RegionSpecifier region_b = 2;
- getRegionB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequestOrBuilder
-
required .RegionSpecifier region_b = 2;
- getRegionBBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- getRegionBBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- getRegionBlockLocations(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionBOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- getRegionBOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
required .RegionSpecifier region_b = 2;
- getRegionBOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
-
required .RegionSpecifier region_b = 2;
- getRegionBOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- getRegionBOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
required .RegionSpecifier region_b = 2;
- getRegionBOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequestOrBuilder
-
required .RegionSpecifier region_b = 2;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
required .RegionInfo region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
required .RegionInfo region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .RegionInfo region = 4;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionByEncodedName(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionByEncodedName(byte[], String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionByStateOfTable(TableName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Gets current state of all regions of the table.
- getRegionCachePrefetch(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
always return false since 0.99
- getRegionCachePrefetch(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
always return false since 0.99
- getRegionCachePrefetch(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
always return false since 0.99
- getRegionCachePrefetch(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
always return false since 0.99
- getRegionCachePrefetch(byte[]) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
always return false since 0.99
- getRegionCachePrefetch(TableName) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
always return false since 0.99
- getRegionCount(Configuration, String) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Deprecated.
- getRegionCount(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Count regions in hbase:meta
for passed table.
- getRegionCount(Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Count regions in hbase:meta
for passed table.
- getRegionCountOfTable(TableName) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
Get region count for table
- getRegionCountOfTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- getRegionDegreeLocalityMappingFromFS(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
This function is to scan the root path of the file system to get the
degree of locality for each region on each of the servers having at least
one block of that region.
- getRegionDegreeLocalityMappingFromFS(Configuration, String, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
This function is to scan the root path of the file system to get the
degree of locality for each region on each of the servers having at least
one block of that region.
- getRegionDir(Path, String) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
- getRegionDir(Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
- getRegionDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getRegionDirRecoveredEditsDir(Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
- getRegionDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Given a particular table dir, return all the regiondirs inside it, excluding files such as
.tableinfo
- getRegionEncodedName(HBaseProtos.RegionSpecifier) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Find the HRegion encoded name based on a region specifier
- getRegionEventDescriptor(Cell) - Static method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionFileSystem() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getRegionFlushedSequenceId(String, String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
- getRegionFlushedSequenceId(String, String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- getRegionFlushedSequenceId(ZooKeeperWatcher, String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
This function is used in distributedLogReplay to fetch last flushed sequence id from ZK
- getRegionId() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
required uint64 region_id = 1;
- getRegionId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
required uint64 region_id = 1;
- getRegionId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
required uint64 region_id = 1;
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
- getRegionInfo(byte[]) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Get the HRegionInfo from cache, if not there, from the hbase:meta table
- getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
-
- getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest, RpcCallback<AdminProtos.GetRegionInfoResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
rpc GetRegionInfo(.GetRegionInfoRequest) returns (.GetRegionInfoResponse);
- getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest, RpcCallback<AdminProtos.GetRegionInfoResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
-
rpc GetRegionInfo(.GetRegionInfoRequest) returns (.GetRegionInfoResponse);
- getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest, RpcCallback<AdminProtos.GetRegionInfoResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
-
- getRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- getRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
repeated .RegionInfo region_info = 1;
- getRegionInfo(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponseOrBuilder
-
repeated .RegionInfo region_info = 1;
- getRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
required .RegionInfo region_info = 1;
- getRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
required .RegionInfo region_info = 1;
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
-
required .RegionInfo region_info = 1;
- getRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
required .RegionInfo regionInfo = 1;
- getRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
required .RegionInfo regionInfo = 1;
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequestOrBuilder
-
required .RegionInfo regionInfo = 1;
- getRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
required .RegionInfo region_info = 1;
- getRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
required .RegionInfo region_info = 1;
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
-
required .RegionInfo region_info = 1;
- getRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
repeated .RegionInfo region_info = 3;
- getRegionInfo(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 3;
- getRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
repeated .RegionInfo region_info = 3;
- getRegionInfo(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 3;
- getRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- getRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
repeated .RegionInfo region_info = 5;
- getRegionInfo(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 5;
- getRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- getRegionInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
repeated .RegionInfo region_info = 2;
- getRegionInfo(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransitionOrBuilder
-
repeated .RegionInfo region_info = 2;
- getRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
required .RegionInfo region_info = 2;
- getRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
required .RegionInfo region_info = 2;
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifestOrBuilder
-
required .RegionInfo region_info = 2;
- getRegionInfo(RpcController, AdminProtos.AdminService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to retrieve region info given a region name
using admin protocol.
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getRegionInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
-
- getRegionInfo(RpcController, AdminProtos.GetRegionInfoRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getRegionInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getRegionInfo(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getRegionInfo_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRegionInfo(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getRegionInfo_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRegionInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRegionInfo(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the regininfo for the specified row.
- getRegionInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRegionInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- getRegionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
required .RegionInfo region_info = 1;
- getRegionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
required .RegionInfo regionInfo = 1;
- getRegionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
required .RegionInfo region_info = 1;
- getRegionInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- getRegionInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- getRegionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
required .RegionInfo region_info = 2;
- getRegionInfoBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- getRegionInfoBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- getRegionInfoBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- getRegionInfoColumn() - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for serialized region info
- getRegionInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- getRegionInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
repeated .RegionInfo region_info = 1;
- getRegionInfoCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponseOrBuilder
-
repeated .RegionInfo region_info = 1;
- getRegionInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
repeated .RegionInfo region_info = 3;
- getRegionInfoCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
repeated .RegionInfo region_info = 3;
- getRegionInfoCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- getRegionInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
repeated .RegionInfo region_info = 5;
- getRegionInfoCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 5;
- getRegionInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- getRegionInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
repeated .RegionInfo region_info = 2;
- getRegionInfoCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransitionOrBuilder
-
repeated .RegionInfo region_info = 2;
- getRegionInfoForDefaultReplica(HRegionInfo) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Returns the HRegionInfo for the default replicaId (0).
- getRegionInfoForFS() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getRegionInfoForFs(HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns the regionInfo object to use for interacting with the file system.
- getRegionInfoForReplica(HRegionInfo, int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
Returns the HRegionInfo for the given replicaId.
- getRegionInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- getRegionInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
repeated .RegionInfo region_info = 1;
- getRegionInfoList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponseOrBuilder
-
repeated .RegionInfo region_info = 1;
- getRegionInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
repeated .RegionInfo region_info = 3;
- getRegionInfoList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
repeated .RegionInfo region_info = 3;
- getRegionInfoList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- getRegionInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
repeated .RegionInfo region_info = 5;
- getRegionInfoList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 5;
- getRegionInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- getRegionInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
repeated .RegionInfo region_info = 2;
- getRegionInfoList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransitionOrBuilder
-
repeated .RegionInfo region_info = 2;
- getRegionInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- getRegionInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
repeated .RegionInfo region_info = 1;
- getRegionInfoOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponseOrBuilder
-
repeated .RegionInfo region_info = 1;
- getRegionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
required .RegionInfo region_info = 1;
- getRegionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
required .RegionInfo region_info = 1;
- getRegionInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
-
required .RegionInfo region_info = 1;
- getRegionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
required .RegionInfo regionInfo = 1;
- getRegionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
required .RegionInfo regionInfo = 1;
- getRegionInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequestOrBuilder
-
required .RegionInfo regionInfo = 1;
- getRegionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
required .RegionInfo region_info = 1;
- getRegionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
required .RegionInfo region_info = 1;
- getRegionInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
-
required .RegionInfo region_info = 1;
- getRegionInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
repeated .RegionInfo region_info = 3;
- getRegionInfoOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
repeated .RegionInfo region_info = 3;
- getRegionInfoOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- getRegionInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
repeated .RegionInfo region_info = 5;
- getRegionInfoOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 5;
- getRegionInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- getRegionInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
repeated .RegionInfo region_info = 2;
- getRegionInfoOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransitionOrBuilder
-
repeated .RegionInfo region_info = 2;
- getRegionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
required .RegionInfo region_info = 2;
- getRegionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
required .RegionInfo region_info = 2;
- getRegionInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifestOrBuilder
-
required .RegionInfo region_info = 2;
- getRegionInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- getRegionInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
repeated .RegionInfo region_info = 1;
- getRegionInfoOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponseOrBuilder
-
repeated .RegionInfo region_info = 1;
- getRegionInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
repeated .RegionInfo region_info = 3;
- getRegionInfoOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
repeated .RegionInfo region_info = 3;
- getRegionInfoOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 3;
- getRegionInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- getRegionInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
repeated .RegionInfo region_info = 5;
- getRegionInfoOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
repeated .RegionInfo region_info = 5;
- getRegionInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- getRegionInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
repeated .RegionInfo region_info = 2;
- getRegionInfoOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransitionOrBuilder
-
repeated .RegionInfo region_info = 2;
- getRegionInfos(AdminProtos.GetOnlineRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Get the list of region info from a GetOnlineRegionResponse
- getRegionLoads(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- getRegionLoads(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .RegionLoad region_loads = 5;
- getRegionLoads(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .RegionLoad region_loads = 5;
- getRegionLoadsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .RegionLoad region_loads = 5;
- getRegionLocation(TableName, byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Find region location hosting passed row
- getRegionLocation(TableName, byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
internal method, do not use thru HConnection
- getRegionLocation(byte[], byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
- getRegionLocation(byte[]) - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(String) - Method in class org.apache.hadoop.hbase.client.HTable
-
- getRegionLocation(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
- getRegionLocation(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
- getRegionLocation(byte[]) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Finds the region on which the given row is being served.
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getRegionLocation() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the region location.
- getRegionLocation(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the HRegionLocation from meta for the given region
- getRegionLocation(Connection, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the HRegionLocation from meta for the given region
- getRegionLocation(int) - Method in class org.apache.hadoop.hbase.RegionLocations
-
- getRegionLocation() - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns the first not-null region location in the list
- getRegionLocationByRegionName(byte[]) - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns the region location from the list for matching regionName, which can
be regionName or encodedRegionName
- getRegionLocations() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getRegionLocations(ClusterConnection, TableName, byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- getRegionLocations(Result) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns an HRegionLocationList extracted from the result.
- getRegionLocations() - Method in class org.apache.hadoop.hbase.RegionLocations
-
- getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a RegionLocator implementation to inspect region information on a table.
- getRegionLocator(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Retrieve a RegionLocator implementation to inspect region information on a table.
- getRegionLocator() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getRegionLocator() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- getRegionLocator(byte[]) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Retrieve a regionLocator for the table.
- getRegionManifests(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifests(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifests(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifestOrBuilder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifests() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get all the Region Manifest from the snapshot
- getRegionManifestsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifestOrBuilder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifestOrBuilder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsMap() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get all the Region Manifest from the snapshot.
- getRegionManifestsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifestOrBuilder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionManifestsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifestOrBuilder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- getRegionMergeCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
Method to retrieve coordination for region merge transaction
- getRegionMergeCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getRegionName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionName() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Get the encoded region name for the region this plan is for.
- getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
-
required bytes region_name = 1;
- getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
required bytes region_name = 1;
- getRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequestOrBuilder
-
required bytes region_name = 1;
- getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
optional bytes region_name = 7;
- getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
optional bytes region_name = 7;
- getRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
optional bytes region_name = 7;
- getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
optional bytes region_name = 6;
- getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
optional bytes region_name = 6;
- getRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
optional bytes region_name = 6;
- getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional bytes region_name = 7;
- getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
optional bytes region_name = 7;
- getRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
optional bytes region_name = 7;
- getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required bytes region_name = 2;
- getRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
required bytes region_name = 2;
- getRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
-
required bytes region_name = 2;
- getRegionName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the name of the region.
- getRegionName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getRegionName() - Method in class org.apache.hadoop.hbase.RegionTransition
-
- getRegionName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getRegionName(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Gets the region name from the full path node name of an unassigned node.
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getRegionNameAsString() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getRegionNameToRegionInfoMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get the regioninfo for a region
- getRegionOpeningState(AdminProtos.OpenRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Get the region opening state from a OpenRegionResponse
- getRegionOpeningStateList(AdminProtos.OpenRegionResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Get a list of region opening state from a OpenRegionResponse
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
required .RegionInfo region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
required .RegionInfo region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
-
required .RegionInfo region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
required .RegionInfo region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
required .RegionInfo region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfoOrBuilder
-
required .RegionInfo region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .RegionInfo region = 4;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
optional .RegionInfo region = 4;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplitOrBuilder
-
optional .RegionInfo region = 4;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
required .RegionSpecifier region = 1;
- getRegionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- getRegionReferenceFileCount(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getRegionReopenPlan(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- getRegionReplicaStoreFileRefreshMultiplier(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- getRegionReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Returns the configured replicas per region
- getRegionResult(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Gets the result in hbase:meta for the specified region.
- getRegions() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- getRegions() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getRegions() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getRegions() - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- getRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
optional int32 regions = 3;
- getRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
optional int32 regions = 3;
- getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegions(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
optional int32 regions = 3;
- getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegions(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionServer(int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager.SinkPeer
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- getRegionServer() - Method in class org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
-
- getRegionServerAccounting() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerAccounting() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getRegionServerCoprocessorHost() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Return the RegionServer-level coprocessors
- getRegionServerFatalLogBuffer() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getRegionServerInfo(ServerName) - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
-
- getRegionServerInfoPort(ServerName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getRegionServerMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerOfRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- getRegionServerQuotaManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionServerQuotaManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getRegionServers() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- getRegionServers() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the live region servers
- getRegionServers() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getRegionServers() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Get a list of all the addresses of all the region servers
for this peer cluster
- getRegionServerServices() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
- getRegionServerServices() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionServerCoprocessorEnvironment
-
Gets the region server services.
- getRegionServerServices() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
Get the RegonServerServices of the server running the transaction or rollback
- getRegionServerServices() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- getRegionServerServices() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
-
Get the RegonServerServices of the server running the transaction or rollback
- getRegionServerServices() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- getRegionServerToRegionMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get regionserver to region map
- getRegionServerWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
-
- getRegionsFromMergeQualifier(Connection, byte[]) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Get regions from the merge qualifier of the specified merged region
- getRegionsFromMeta(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- getRegionsFromMeta() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- getRegionsInRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
This is no longer a public API
- getRegionsInRange(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
This is no longer a public API
- getRegionsInTransition() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRegionsInTransition() - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Get regions in transition and their states
- getRegionsInTransition(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransition(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransition(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionInRS() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRegionsInTransitionInRS() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Get the regions that are currently being opened or closed in the RS
- getRegionsInTransitionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionsInTransitionOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
repeated .RegionInTransition regions_in_transition = 4;
- getRegionSize(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSizeCalculator
-
Returns size of given region in bytes.
- getRegionSizeMap() - Method in class org.apache.hadoop.hbase.util.RegionSizeCalculator
-
- getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsLoad() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRegionsMovement(FavoredNodesPlan) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
Return how many regions will move per table since their primary RS will
change
- getRegionsOfTable(TableName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Gets the online regions of the specified table.
- getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- getRegionSpecifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
required .RegionSpecifier region_specifier = 1;
- getRegionSpecifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
required .RegionSpecifier region_specifier = 1;
- getRegionSpecifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
required .RegionSpecifier region_specifier = 1;
- getRegionSpecifierBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
required .RegionSpecifier region_specifier = 1;
- getRegionSpecifierOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
required .RegionSpecifier region_specifier = 1;
- getRegionSpecifierOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
required .RegionSpecifier region_specifier = 1;
- getRegionSpecifierOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
required .RegionSpecifier region_specifier = 1;
- getRegionSplitLimit() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getRegionSplitPolicyClassName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
This gets the class associated with the region split policy which
determines when a region split should occur.
- getRegionsResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getRegionState(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- getRegionState(String) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
- getRegionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionState region_state = 2;
- getRegionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
required .RegionState region_state = 2;
- getRegionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
-
required .RegionState region_state = 2;
- getRegionStateBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionState region_state = 2;
- getRegionStateOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionState region_state = 2;
- getRegionStateOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
required .RegionState region_state = 2;
- getRegionStateOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
-
required .RegionState region_state = 2;
- getRegionStates() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
This SHOULD not be public.
- getRegionStats() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRegionsToAdd() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the list of new regions added during the on-disk restore.
- getRegionsToRemove() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the list of regions removed during the on-disk restore.
- getRegionsToRestore() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
Returns the list of 'restored regions' during the on-disk restore.
- getRegionToFlush(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
repeated bytes region_to_flush = 1;
- getRegionToFlush(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
repeated bytes region_to_flush = 1;
- getRegionToFlush(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponseOrBuilder
-
repeated bytes region_to_flush = 1;
- getRegionToFlushCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
repeated bytes region_to_flush = 1;
- getRegionToFlushCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
repeated bytes region_to_flush = 1;
- getRegionToFlushCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponseOrBuilder
-
repeated bytes region_to_flush = 1;
- getRegionToFlushList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
repeated bytes region_to_flush = 1;
- getRegionToFlushList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
repeated bytes region_to_flush = 1;
- getRegionToFlushList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponseOrBuilder
-
repeated bytes region_to_flush = 1;
- getRegionToRegionServerMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get region to region server map
- getRegionTransitionState(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Get region transition state
- getRegionTransitionState(String) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Get region transition state
- getRegionWrapper() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegion
-
- getRemaining() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getRemaining() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
The number of bytes remaining between position and the end of the range.
- getRemoteAddress() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
- getRemoteAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
-
- getRemoteAddress() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getRemoteAddress() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getRemoteException(ServiceException) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Return the IOException thrown by the remote server wrapped in
ServiceException as cause.
- getRemoteIp() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the remote side ip address when invoked inside an RPC
Returns null incase of an error.
- getRemotePort() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- getRemoteUser() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getRemoveAll() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional bool remove_all = 5;
- getRemoveAll() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional bool remove_all = 5;
- getRemoveAll() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional bool remove_all = 5;
- getRenew() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool renew = 10 [default = false];
- getRenew() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional bool renew = 10 [default = false];
- getRenew() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional bool renew = 10 [default = false];
- getRenewer() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
- getReopenStatus(TableName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Used by the client to identify if all regions have the schema updates
- getReplicaCallTimeoutMicroSecondScan() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getReplicaId() - Method in class org.apache.hadoop.hbase.client.Action
-
- getReplicaId() - Method in class org.apache.hadoop.hbase.client.Query
-
Returns region replica id where Query will fetch data from.
- getReplicaId() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Returns the region replica id
- getReplicaId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional int32 replica_id = 7 [default = 0];
- getReplicaId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
optional int32 replica_id = 7 [default = 0];
- getReplicaId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
optional int32 replica_id = 7 [default = 0];
- getReplicaId() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getReplicasToClose() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- getReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
optional string replicationEndpointImpl = 2;
- getReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
optional string replicationEndpointImpl = 2;
- getReplicationEndpointImpl() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
optional string replicationEndpointImpl = 2;
- getReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
- getReplicationEndpointImplBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
optional string replicationEndpointImpl = 2;
- getReplicationEndpointImplBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
optional string replicationEndpointImpl = 2;
- getReplicationEndpointImplBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
optional string replicationEndpointImpl = 2;
- getReplicationLag() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint64 replicationLag = 5;
- getReplicationLag() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
required uint64 replicationLag = 5;
- getReplicationLag() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
-
required uint64 replicationLag = 5;
- getReplicationLag() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getReplicationLoadSink() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
- getReplicationLoadSink() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Call directly from client such as hbase shell
- getReplicationLoadSourceList() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
- getReplicationLoadSourceList() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Call directly from client such as hbase shell
- getReplicationManager() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Get the replication sources manager
- getReplicationPeer() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getReplicationPeerConfig(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Returns the configured ReplicationPeerConfig for this peerId
- getReplicationPeerConfig(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
Returns a ReplicationPeerConfig from the znode or null for the given peerId.
- getReplicationPeerId() - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Return the peer id used for replicating to secondary region replicas
- getReplicationPeers(ZooKeeperWatcher, Configuration, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
-
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- getReplicationQueueLength() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Retrieves length of the replication queue for metrics.
- getReplicationQueueLength() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- getReplicationQueues(ZooKeeperWatcher, Configuration, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
-
- getReplicationQueuesClient(ZooKeeperWatcher, Configuration, Abortable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
-
- getReplicationSink() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
-
Get a randomly-chosen replication sink to replicate to.
- getReplicationSource(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Server, String, UUID, ReplicationPeerConfig, ReplicationPeer) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Factory method to create a replication source
- getReplicationTracker(ZooKeeperWatcher, ReplicationPeers, Configuration, Abortable, Stoppable) - Static method in class org.apache.hadoop.hbase.replication.ReplicationFactory
-
- getReplLoadSink() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional .ReplicationLoadSink replLoadSink = 11;
- getReplLoadSink() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional .ReplicationLoadSink replLoadSink = 11;
- getReplLoadSink() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional .ReplicationLoadSink replLoadSink = 11;
- getReplLoadSinkBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional .ReplicationLoadSink replLoadSink = 11;
- getReplLoadSinkOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional .ReplicationLoadSink replLoadSink = 11;
- getReplLoadSinkOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional .ReplicationLoadSink replLoadSink = 11;
- getReplLoadSinkOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional .ReplicationLoadSink replLoadSink = 11;
- getReplLoadSource(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSource(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSource(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReplLoadSourceOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- getReportEndTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 report_end_time = 8;
- getReportEndTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint64 report_end_time = 8;
- getReportEndTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint64 report_end_time = 8;
- getReportStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 report_start_time = 7;
- getReportStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint64 report_start_time = 7;
- getReportStartTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint64 report_start_time = 7;
- getReqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_num = 1;
- getReqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota req_num = 1;
- getReqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota req_num = 1;
- getReqNumBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_num = 1;
- getReqNumOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_num = 1;
- getReqNumOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota req_num = 1;
- getReqNumOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota req_num = 1;
- getReqSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_size = 2;
- getReqSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota req_size = 2;
- getReqSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota req_size = 2;
- getReqSizeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_size = 2;
- getReqSizeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_size = 2;
- getReqSizeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota req_size = 2;
- getReqSizeOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota req_size = 2;
- getRequest() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required bytes request = 4;
- getRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
required bytes request = 4;
- getRequest() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
-
required bytes request = 4;
- getRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- getRequest() - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- getRequest() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getRequestCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getRequestCachingCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getRequestCount() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getRequestCount() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getRequestData() - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getRequestData() - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
This method should return any additional data that is needed on the
server side to construct the ColumnInterpreter.
- getRequestData() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
This method should return any additional data that is needed on the
server side to construct the RowProcessor.
- getRequestLog(String) - Static method in class org.apache.hadoop.hbase.http.HttpRequestLog
-
- getRequestParam() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional bool request_param = 4;
- getRequestParam() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional bool request_param = 4;
- getRequestParam() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional bool request_param = 4;
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
-
- getRequestPrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService
-
- getRequests() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- getRequests() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
optional int64 requests = 4;
- getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
optional int64 requests = 4;
- getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int64 requests = 3;
- getRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
optional int64 requests = 3;
- getRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
optional int64 requests = 3;
- getRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
optional int64 requests = 4;
- getRequestsCount() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getRequestsPerSecond() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of requests per second.
- getRequestsPerSecond() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRequestURL() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
Quote the url so that users specifying the HOST HTTP header
can't inject attacks.
- getRequestUser() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Returns the user credentials associated with the current RPC request or
null
if no credentials were provided.
- getRequestUser() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getRequestUser() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the user credentials associated with the current RPC request or
null
if no credentials were provided.
- getRequestUser() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
-
- getRequestUserName() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
- getRequestUserName() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getRequestUserName() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Returns the username for any user associated with the current RPC
request or null
if no user is set.
- getRescanNode(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- getResource(String) - Method in class org.apache.hadoop.hbase.util.CoprocessorClassLoader
-
- getResponse() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
-
optional uint32 response = 1;
- getResponse() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
optional uint32 response = 1;
- getResponse() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponseOrBuilder
-
optional uint32 response = 1;
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
-
- getResponsePrototype(Descriptors.MethodDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService
-
- getRestVersion() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- getRESTVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string restVersion = 1;
- getRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string restVersion = 1;
- getRestVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string restVersion = 1;
- getRestVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string restVersion = 1;
- getRestVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string restVersion = 1;
- getRestVersionBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string restVersion = 1;
- getResult() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getResult(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getResult() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
optional .Result result = 1;
- getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
optional .Result result = 1;
- getResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponseOrBuilder
-
optional .Result result = 1;
- getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
optional .Result result = 1;
- getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
optional .Result result = 1;
- getResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponseOrBuilder
-
optional .Result result = 1;
- getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .Result result = 2;
- getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional .Result result = 2;
- getResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional .Result result = 2;
- getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional bytes result = 4;
- getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
optional bytes result = 4;
- getResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
-
optional bytes result = 4;
- getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional bytes result = 11;
- getResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional bytes result = 11;
- getResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional bytes result = 11;
- getResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- getResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
repeated .RegionActionResult result = 1;
- getResult(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponseOrBuilder
-
repeated .RegionActionResult result = 1;
- getResult() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
-
- getResult() - Method in interface org.apache.hadoop.hbase.regionserver.Region.FlushResult
-
- getResult() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Obtain the processing result.
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.append_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.atomicIncrement_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.checkAndPut_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.compact_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.createTable_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAll_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRow_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRowTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteTable_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.disableTable_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.enableTable_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.get_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getColumnDescriptors_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRegionInfo_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRow_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowOrBefore_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRows_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumns_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumnsTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumns_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumnsTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableNames_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableRegions_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVer_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVerTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.increment_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.incrementRows_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.isTableEnabled_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.majorCompact_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRow_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRows_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowsTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerClose_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGet_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGetList_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpen_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenTs_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithPrefix_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithScan_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStop_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStopTs_call
-
- getResult(I, Hbase.append_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.append
-
- getResult(I, Hbase.atomicIncrement_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.atomicIncrement
-
- getResult(I, Hbase.checkAndPut_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.checkAndPut
-
- getResult(I, Hbase.compact_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.compact
-
- getResult(I, Hbase.createTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.createTable
-
- getResult(I, Hbase.deleteAll_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAll
-
- getResult(I, Hbase.deleteAllRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRow
-
- getResult(I, Hbase.deleteAllRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRowTs
-
- getResult(I, Hbase.deleteAllTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllTs
-
- getResult(I, Hbase.deleteTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteTable
-
- getResult(I, Hbase.disableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.disableTable
-
- getResult(I, Hbase.enableTable_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.enableTable
-
- getResult(I, Hbase.get_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.get
-
- getResult(I, Hbase.getColumnDescriptors_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getColumnDescriptors
-
- getResult(I, Hbase.getRegionInfo_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRegionInfo
-
- getResult(I, Hbase.getRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRow
-
- getResult(I, Hbase.getRowOrBefore_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowOrBefore
-
- getResult(I, Hbase.getRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRows
-
- getResult(I, Hbase.getRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsTs
-
- getResult(I, Hbase.getRowsWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumns
-
- getResult(I, Hbase.getRowsWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumnsTs
-
- getResult(I, Hbase.getRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowTs
-
- getResult(I, Hbase.getRowWithColumns_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumns
-
- getResult(I, Hbase.getRowWithColumnsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumnsTs
-
- getResult(I, Hbase.getTableNames_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableNames
-
- getResult(I, Hbase.getTableRegions_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableRegions
-
- getResult(I, Hbase.getVer_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVer
-
- getResult(I, Hbase.getVerTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVerTs
-
- getResult(I, Hbase.increment_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.increment
-
- getResult(I, Hbase.incrementRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.incrementRows
-
- getResult(I, Hbase.isTableEnabled_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.isTableEnabled
-
- getResult(I, Hbase.majorCompact_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.majorCompact
-
- getResult(I, Hbase.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRow
-
- getResult(I, Hbase.mutateRows_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRows
-
- getResult(I, Hbase.mutateRowsTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowsTs
-
- getResult(I, Hbase.mutateRowTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowTs
-
- getResult(I, Hbase.scannerClose_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerClose
-
- getResult(I, Hbase.scannerGet_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGet
-
- getResult(I, Hbase.scannerGetList_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGetList
-
- getResult(I, Hbase.scannerOpen_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpen
-
- getResult(I, Hbase.scannerOpenTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenTs
-
- getResult(I, Hbase.scannerOpenWithPrefix_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithPrefix
-
- getResult(I, Hbase.scannerOpenWithScan_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithScan
-
- getResult(I, Hbase.scannerOpenWithStop_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStop
-
- getResult(I, Hbase.scannerOpenWithStopTs_args) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStopTs
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.append_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndDelete_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndPut_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.closeScanner_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteMultiple_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteSingle_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.exists_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.get_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getMultiple_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerResults_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.getScannerRows_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.increment_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.mutateRow_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.openScanner_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.put_call
-
- getResult() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.putMultiple_call
-
- getResult(I, THBaseService.append_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.append
-
- getResult(I, THBaseService.checkAndDelete_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndDelete
-
- getResult(I, THBaseService.checkAndPut_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndPut
-
- getResult(I, THBaseService.closeScanner_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.closeScanner
-
- getResult(I, THBaseService.deleteMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteMultiple
-
- getResult(I, THBaseService.deleteSingle_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteSingle
-
- getResult(I, THBaseService.exists_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.exists
-
- getResult(I, THBaseService.get_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.get
-
- getResult(I, THBaseService.getMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getMultiple
-
- getResult(I, THBaseService.getScannerResults_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerResults
-
- getResult(I, THBaseService.getScannerRows_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.getScannerRows
-
- getResult(I, THBaseService.increment_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.increment
-
- getResult(I, THBaseService.mutateRow_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.mutateRow
-
- getResult(I, THBaseService.openScanner_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.openScanner
-
- getResult(I, THBaseService.put_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.put
-
- getResult(I, THBaseService.putMultiple_args) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.putMultiple
-
- getResultBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
optional .Result result = 1;
- getResultBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
optional .Result result = 1;
- getResultBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .Result result = 2;
- getResultBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- getResultBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- getResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- getResultCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
repeated .RegionActionResult result = 1;
- getResultCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponseOrBuilder
-
repeated .RegionActionResult result = 1;
- getResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- getResultList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
repeated .RegionActionResult result = 1;
- getResultList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponseOrBuilder
-
repeated .RegionActionResult result = 1;
- getResultOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
optional .Result result = 1;
- getResultOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
optional .Result result = 1;
- getResultOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponseOrBuilder
-
optional .Result result = 1;
- getResultOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
optional .Result result = 1;
- getResultOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
optional .Result result = 1;
- getResultOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponseOrBuilder
-
optional .Result result = 1;
- getResultOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .Result result = 2;
- getResultOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional .Result result = 2;
- getResultOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional .Result result = 2;
- getResultOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- getResultOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
repeated .RegionActionResult result = 1;
- getResultOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponseOrBuilder
-
repeated .RegionActionResult result = 1;
- getResultOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- getResultOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
repeated .RegionActionResult result = 1;
- getResultOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponseOrBuilder
-
repeated .RegionActionResult result = 1;
- getResultOrException(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- getResultOrException(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
repeated .ResultOrException resultOrException = 1;
- getResultOrException(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResultOrBuilder
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResultOrBuilder
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResultOrBuilder
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResultOrBuilder
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
repeated .ResultOrException resultOrException = 1;
- getResultOrExceptionOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResultOrBuilder
-
repeated .ResultOrException resultOrException = 1;
- getResultOrProcedure(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getResults() - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- getResults() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getResults(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- getResults(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
repeated .Result results = 5;
- getResults(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
repeated .Result results = 5;
- getResults(ClientProtos.MultiRequest, ClientProtos.MultiResponse, CellScanner) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Get the results from a protocol buffer MultiResponse
- getResults(CellScanner, ClientProtos.ScanResponse) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Create Results from the cells using the cells meta data.
- getResultsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- getResultsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- getResultsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- getResultsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
repeated .Result results = 5;
- getResultsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
repeated .Result results = 5;
- getResultsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- getResultsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
repeated .Result results = 5;
- getResultsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
repeated .Result results = 5;
- getResultsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- getResultsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
repeated .Result results = 5;
- getResultsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
repeated .Result results = 5;
- getResultsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- getResultsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
repeated .Result results = 5;
- getResultsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
repeated .Result results = 5;
- getResultsToAddToCache(Result[], boolean) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
This method ensures all of our book keeping regarding partial results is kept up to date.
- getRetainDays() - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- getRetCode() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- getRetries() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getRetriesNumber() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getReturnData() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
optional bytes return_data = 2;
- getReturnData() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
optional bytes return_data = 2;
- getReturnData() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponseOrBuilder
-
optional bytes return_data = 2;
- getReversed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool reversed = 15 [default = false];
- getReversed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bool reversed = 15 [default = false];
- getReversed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bool reversed = 15 [default = false];
- getRevision() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string revision = 3;
- getRevision() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string revision = 3;
- getRevision() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string revision = 3;
- getRevision() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the subversion revision number for the root directory
- getRevisionBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string revision = 3;
- getRevisionBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string revision = 3;
- getRevisionBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string revision = 3;
- getRoot() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
get/set
- getRootBlockCount() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootBlockDataSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootBlockKey(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootBlockOffset(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- getRootDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getRootDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRootDir(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 root_index_size_KB = 12;
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 root_index_size_KB = 12;
- getRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 root_index_size_KB = 12;
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 rootIndexSizeKB = 9;
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 rootIndexSizeKB = 9;
- getRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 rootIndexSizeKB = 9;
- getRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getRootKeyZNode() - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- getRootProcedureId(Map<Long, Procedure>, Procedure) - Static method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getRow() - Method in interface org.apache.hadoop.hbase.Cell
-
- getRow() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's row
- getRow() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the delete's row
- getRow() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- getRow() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getRow() - Method in class org.apache.hadoop.hbase.client.Result
-
Method for retrieving the row key that corresponds to
the row from which this Result was created.
- getRow(int) - Method in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
-
- getRow() - Method in interface org.apache.hadoop.hbase.client.Row
-
- getRow() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- getRow() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getRow() - Method in class org.apache.hadoop.hbase.KeyValue
-
Deprecated.
- getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional bytes row = 1;
- getRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
required bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
required bytes row = 1;
- getRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
required bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
required bytes row = 1;
- getRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
-
required bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
required bytes row = 1;
- getRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
-
required bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
required bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
required bytes row = 1;
- getRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
required bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional bytes row = 1;
- getRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
optional bytes row = 1;
- getRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
optional bytes row = 1;
- getRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getRow() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
Deprecated.
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRow_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRow_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
row to increment
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
row key
- getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Row to update
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
key of the row to be completely deleted.
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
key of the row to be completely deleted.
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Row to update
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
row key
- getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get all the data for the specified table and row at the latest
timestamp.
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
row key
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
row to check
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
row to check
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- getRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- getRowArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getRowArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getRowArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getRowArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getRowArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getRowBatches() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
list of row batches
- getRowBatches() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
list of row batches
- getRowBatchesIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- getRowBatchesIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- getRowBatchesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- getRowBatchesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- getRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required uint32 rowBatchSize = 4;
- getRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
required uint32 rowBatchSize = 4;
- getRowBatchSize() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
-
required uint32 rowBatchSize = 4;
- getRowBufferLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- getRowByte(Cell, int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
misc
- getRowComparator() - Method in class org.apache.hadoop.hbase.TableName
-
Deprecated.
The comparator is an internal property of the table. Should
not have been exposed here
- getRowCount(RpcController, ExampleProtos.CountRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.BlockingInterface
-
- getRowCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
-
rpc getRowCount(.CountRequest) returns (.CountResponse);
- getRowCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.Interface
-
rpc getRowCount(.CountRequest) returns (.CountResponse);
- getRowCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService.Stub
-
- getRowCount(RpcController, ExampleProtos.CountRequest, RpcCallback<ExampleProtos.CountResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
-
Returns a count of the rows in the region where this coprocessor is loaded.
- getRowKeyAtOrBefore(GetClosestRowBeforeTracker) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- getRowKeyAtOrBefore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getRowKeyAtOrBefore(GetClosestRowBeforeTracker) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Find the key that matches row exactly, or the one that immediately precedes it.
- getRowKeyAtOrBefore(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Find the key that matches row exactly, or the one that immediately precedes it.
- getRowKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getRowLength() - Method in interface org.apache.hadoop.hbase.Cell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getRowLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getRowLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getRowLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getRowLock(byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getRowLock(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Acquires a lock on the given row.
- getRowLock(byte[], boolean) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Tries to acquire a lock on the given row.
- getRowLockInternal(byte[], boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
A version of getRowLock(byte[], boolean) to use when a region operation has already been
started (the calling thread has already acquired the region-close-guard lock).
- getRowMutations() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
mutations to apply
- getRowNum(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives the row count for the given column family and column qualifier, in
the given row range as defined in the Scan object.
- getRowNum(RpcController, AggregateProtos.AggregateRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
-
- getRowNum(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
rpc GetRowNum(.AggregateRequest) returns (.AggregateResponse);
- getRowNum(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
-
rpc GetRowNum(.AggregateRequest) returns (.AggregateResponse);
- getRowNum(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
-
- getRowOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getRowOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's offset per row per column
family (#kvs to be skipped)
- getRowOffsetPerColumnFamily() - Method in class org.apache.hadoop.hbase.client.Scan
-
Method for retrieving the scan's offset per row per column
family (#kvs to be skipped)
- getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
Use reversed scan instead.
- getRowOrBefore(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Deprecated.
As of version 0.92 this method is deprecated without
replacement. Since version 0.96+, you can use reversed scan.
getRowOrBefore is used internally to find entries in hbase:meta and makes
various assumptions about the table (which are true for hbase:meta but not
in general) to be efficient.
- getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
Deprecated.
- getRowOrBefore(ClientProtos.ClientService.BlockingInterface, byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Deprecated.
since 0.99 - use reversed scanner instead.
- getRowOrBefore(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getRowOrBefore_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getRowOrBefore_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the row just before the specified one.
- getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Deprecated.
- getRowProcessorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
required string row_processor_class_name = 1;
- getRowProcessorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
required string row_processor_class_name = 1;
- getRowProcessorClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
-
required string row_processor_class_name = 1;
- getRowProcessorClassNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
required string row_processor_class_name = 1;
- getRowProcessorClassNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
required string row_processor_class_name = 1;
- getRowProcessorClassNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
-
required string row_processor_class_name = 1;
- getRowProcessorInitializerMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional bytes row_processor_initializer_message = 3;
- getRowProcessorInitializerMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
optional bytes row_processor_initializer_message = 3;
- getRowProcessorInitializerMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
-
optional bytes row_processor_initializer_message = 3;
- getRowProcessorInitializerMessageName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional string row_processor_initializer_message_name = 2;
- getRowProcessorInitializerMessageName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
optional string row_processor_initializer_message_name = 2;
- getRowProcessorInitializerMessageName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
-
optional string row_processor_initializer_message_name = 2;
- getRowProcessorInitializerMessageNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional string row_processor_initializer_message_name = 2;
- getRowProcessorInitializerMessageNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
optional string row_processor_initializer_message_name = 2;
- getRowProcessorInitializerMessageNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
-
optional string row_processor_initializer_message_name = 2;
- getRowProcessorPB(RowProcessor<S, T>) - Static method in class org.apache.hadoop.hbase.client.coprocessor.RowProcessorClient
-
- getRowProcessorResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
-
required bytes row_processor_result = 1;
- getRowProcessorResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
required bytes row_processor_result = 1;
- getRowProcessorResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponseOrBuilder
-
required bytes row_processor_result = 1;
- getRowRangeList(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- getRowRangeList(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
repeated .RowRange row_range_list = 1;
- getRowRangeList(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilterOrBuilder
-
repeated .RowRange row_range_list = 1;
- getRowRangeListBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- getRowRangeListBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- getRowRangeListCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- getRowRangeListCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
repeated .RowRange row_range_list = 1;
- getRowRangeListCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilterOrBuilder
-
repeated .RowRange row_range_list = 1;
- getRowRangeListList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- getRowRangeListList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
repeated .RowRange row_range_list = 1;
- getRowRangeListList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilterOrBuilder
-
repeated .RowRange row_range_list = 1;
- getRowRangeListOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- getRowRangeListOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
repeated .RowRange row_range_list = 1;
- getRowRangeListOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilterOrBuilder
-
repeated .RowRange row_range_list = 1;
- getRowRangeListOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- getRowRangeListOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
repeated .RowRange row_range_list = 1;
- getRowRangeListOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilterOrBuilder
-
repeated .RowRange row_range_list = 1;
- getRowRanges() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
- getRowResource(String, String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getRowResourceWithSuffixGlobbing(String, String, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getRows() - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
- getRows(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRows(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRows(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRows_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRows_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
row keys
- getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
row keys
- getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
row keys
- getRows() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
row keys
- getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get all the data for the specified table and rows at the latest
timestamp.
- getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
required uint64 rowsDeleted = 1;
- getRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
required uint64 rowsDeleted = 1;
- getRowsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
-
required uint64 rowsDeleted = 1;
- getRowsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- getRowsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- getRowsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- getRowsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getRowsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSetOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- getRowsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- getRowsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- getRowsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- getRowsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getRowsToLock() - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
-
Rows to lock while operation.
- getRowString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get all the data for the specified table and rows at the specified
timestamp.
- getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumns_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumns_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the specified columns for the specified table and rows at the latest
timestamp.
- getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumnsTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumnsTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the specified columns for the specified table and rows at the specified
timestamp.
- getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowTokenizer() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getRowTreeDepth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get all the data for the specified table and row at the specified
timestamp.
- getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumns_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumns_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the specified columns for the specified table and row at the latest
timestamp.
- getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumnsTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumnsTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the specified columns for the specified table and row at the specified
timestamp.
- getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getRowWriter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getRPC() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPC(boolean) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPC() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Produces a string representation of the method currently being serviced
by this Handler.
- getRPC(boolean) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Produces a string representation of the method currently being serviced
by this Handler.
- getRpcControllerFactory() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- getRPCPacketLength() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPCPacketLength() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Produces a string representation of the method currently being serviced
by this Handler.
- getRPCQueueTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPCQueueTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Accesses the queue time for the currently running RPC on the
monitored Handler.
- getRpcRetryingCallerFactory() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- getRpcServer() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRpcServer() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
Returns a reference to the region server's RPC server
- getRPCStartTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- getRPCStartTime() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Accesses the start time for the currently running RPC on the
monitored Handler.
- getRpcTimeout() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getRpcTimeout() - Method in class org.apache.hadoop.hbase.ipc.AsyncCall
-
Get the rpc timeout
- getRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
optional uint32 rpc_version = 2;
- getRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
optional uint32 rpc_version = 2;
- getRpcVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
-
optional uint32 rpc_version = 2;
- getRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
optional uint32 rpc_version = 2;
- getRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
optional uint32 rpc_version = 2;
- getRpcVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServerOrBuilder
-
optional uint32 rpc_version = 2;
- getRsCoprocessors() - Method in class org.apache.hadoop.hbase.ServerLoad
-
Return the RegionServer-level and Region-level coprocessors
- getRSRpcServices() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getRunnableSet() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- gets - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
a list of TGets to fetch, the Result list
will have the Results at corresponding positions
or null if there was an error
- getSampleCount() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Returns the number of samples kept by the estimator
- getSaslQop() - Method in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
- getScan() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getScan() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- getScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required .Scan scan = 1;
- getScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
required .Scan scan = 1;
- getScan() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
-
required .Scan scan = 1;
- getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Gets the scan defining the actual details like columns etc.
- getScan() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns a Scan object from the stored string representation.
- getScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required .Scan scan = 2;
- getScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
required .Scan scan = 2;
- getScan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequestOrBuilder
-
required .Scan scan = 2;
- getScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .Scan scan = 2;
- getScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional .Scan scan = 2;
- getScan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional .Scan scan = 2;
- getScan() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Scan instance
- getScan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
the scan object to get a Scanner for
- getScan() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
the scan object to get a Scanner for
- getScanBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required .Scan scan = 1;
- getScanBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required .Scan scan = 2;
- getScanBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .Scan scan = 2;
- getScanForTableName(TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
This method creates a Scan object that will only scan catalog rows that
belong to the specified table.
- getScanInfo(Store, RegionCoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- getScanInfo() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getScanInfo() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getScanLabelGenerators(Configuration) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- getScanMetrics() - Method in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
Used internally accumulating metrics on scan.
- getScanMetrics() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.client.HTable
-
The underlying
HTable
must not be closed.
- getScanner(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
The underlying
HTable
must not be closed.
- getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
The underlying
HTable
must not be closed.
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getScanner(byte[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getScanner(Scan) - Method in interface org.apache.hadoop.hbase.client.Table
-
Returns a scanner on the current table as specified by the
Scan
object.
- getScanner(byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets a scanner on the current table for the given family.
- getScanner(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Table
-
Gets a scanner on the current table for the given family and qualifier.
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- getScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Create a Scanner on this file.
- getScanner(boolean, boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getScanner(boolean, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
Create a Scanner on this file.
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
-
Create a Scanner on this file.
- getScanner() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
-
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getScanner(Scan, NavigableSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getScanner() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getScanner(Scan) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return an iterator that scans over the HRegion, returning the indicated
columns and rows specified by the
Scan
.
- getScanner(Scan, NavigableSet<byte[]>, long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Return a scanner for both the memstore and the HStore files.
- getScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
Deprecated.
- getScanner(boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
Deprecated.
- getScanner(Scan) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getScanner(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getScanner(byte[], byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getScanner(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Returns the scanner associated with the specified ID.
- getScanner() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.ResultScannerWrapper
-
- getScannerCaching() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getScannerCaching() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getScannerCallable(byte[], int) - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getScannerCallable(byte[], int, byte[]) - Method in class org.apache.hadoop.hbase.client.ReversedClientScanner
-
- getScannerCallableForReplica(int) - Method in class org.apache.hadoop.hbase.client.ReversedScannerCallable
-
- getScannerCallableForReplica(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- getScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional uint64 scanner_id = 3;
- getScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional uint64 scanner_id = 3;
- getScannerId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional uint64 scanner_id = 3;
- getScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional uint64 scanner_id = 2;
- getScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
optional uint64 scanner_id = 2;
- getScannerId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
optional uint64 scanner_id = 2;
- getScannerId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
the Id of the Scanner to close *
- getScannerId() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
the Id of the Scanner to return rows from.
- getScannerInstanceResource(String) - Method in class org.apache.hadoop.hbase.rest.ScannerResource
-
- getScannerMaxResultSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getScannerResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getScannerResults(ByteBuffer, TScan, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerResults_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- getScannerResults(ByteBuffer, TScan, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerResults_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- getScannerResults(ByteBuffer, TScan, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- getScannerResults(ByteBuffer, TScan, int) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Get results for the provided TScan object.
- getScannerResults(ByteBuffer, TScan, int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getScannerRows(int, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerRows_call>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- getScannerRows(int, int, AsyncMethodCallback<THBaseService.AsyncClient.getScannerRows_call>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- getScannerRows(int, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- getScannerRows(int, int) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Grabs multiple rows from a Scanner.
- getScannerRows(int, int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- getScanners(long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- getScanners(boolean, boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Get all scanners with no filtering based on TTL (that happens further down
the line).
- getScanners(long) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
- getScanners(boolean, boolean, boolean, boolean, ScanQueryMatcher, byte[], byte[], long) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Get all scanners with no filtering based on TTL (that happens further down
the line).
- getScannersForStoreFiles(Collection<StoreFile>, boolean, boolean, long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Return an array of scanners corresponding to the given
set of store files.
- getScannersForStoreFiles(Collection<StoreFile>, boolean, boolean, boolean, long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Return an array of scanners corresponding to the given set of store files.
- getScannersForStoreFiles(Collection<StoreFile>, boolean, boolean, boolean, ScanQueryMatcher, long) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
Return an array of scanners corresponding to the given set of store files,
And set the ScanQueryMatcher for each store file scanner for further
optimization
- getScannersNoCompaction() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Get a filtered list of scanners.
- getScannerTimeout() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getScanOrBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required .Scan scan = 1;
- getScanOrBuilder() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
required .Scan scan = 1;
- getScanOrBuilder() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
-
required .Scan scan = 1;
- getScanOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required .Scan scan = 2;
- getScanOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
required .Scan scan = 2;
- getScanOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequestOrBuilder
-
required .Scan scan = 2;
- getScanOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .Scan scan = 2;
- getScanOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional .Scan scan = 2;
- getScanOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional .Scan scan = 2;
- getScanResource(UriInfo, String, String, int, String, String, List<String>, int, int, long, long, boolean, String) - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getScanResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
-
optional int32 scan_result = 1;
- getScanResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
optional int32 scan_result = 1;
- getScanResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponseOrBuilder
-
optional int32 scan_result = 1;
- getScans() - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to get the list of
Scan
objects.
- getScheduler() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getScheduler() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- getSchemaAlterStatus(RpcController, MasterProtos.GetSchemaAlterStatusRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Get the number of regions of the table that have been updated by the alter.
- getSchemaAlterStatus(RpcController, MasterProtos.GetSchemaAlterStatusRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- getSchemaAlterStatus(RpcController, MasterProtos.GetSchemaAlterStatusRequest, RpcCallback<MasterProtos.GetSchemaAlterStatusResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc GetSchemaAlterStatus(.GetSchemaAlterStatusRequest) returns (.GetSchemaAlterStatusResponse);
- getSchemaAlterStatus(RpcController, MasterProtos.GetSchemaAlterStatusRequest, RpcCallback<MasterProtos.GetSchemaAlterStatusResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc GetSchemaAlterStatus(.GetSchemaAlterStatusRequest) returns (.GetSchemaAlterStatusResponse);
- getSchemaAlterStatus(RpcController, MasterProtos.GetSchemaAlterStatusRequest, RpcCallback<MasterProtos.GetSchemaAlterStatusResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- getSchemaResource() - Method in class org.apache.hadoop.hbase.rest.TableResource
-
- getScheme(HttpConfig.Policy) - Method in class org.apache.hadoop.hbase.http.HttpConfig
-
- getSchemePrefix() - Method in class org.apache.hadoop.hbase.http.HttpConfig
-
- getScope() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getScope() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
optional .QuotaScope scope = 4 [default = MACHINE];
- getScope() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
optional .QuotaScope scope = 4 [default = MACHINE];
- getScope() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuotaOrBuilder
-
optional .QuotaScope scope = 4 [default = MACHINE];
- getScopes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- getScopes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
repeated .FamilyScope scopes = 6;
- getScopes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
repeated .FamilyScope scopes = 6;
- getScopes() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getScopesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- getScopesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- getScopesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- getScopesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
repeated .FamilyScope scopes = 6;
- getScopesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
repeated .FamilyScope scopes = 6;
- getScopesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- getScopesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
repeated .FamilyScope scopes = 6;
- getScopesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
repeated .FamilyScope scopes = 6;
- getScopesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- getScopesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
repeated .FamilyScope scopes = 6;
- getScopesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
repeated .FamilyScope scopes = 6;
- getScopesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- getScopesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
repeated .FamilyScope scopes = 6;
- getScopesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
repeated .FamilyScope scopes = 6;
- getScopeType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
required .ScopeType scope_type = 2;
- getScopeType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
required .ScopeType scope_type = 2;
- getScopeType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScopeOrBuilder
-
required .ScopeType scope_type = 2;
- getScopeWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
Returns a WALEntryFilter for checking the scope.
- getScopeWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- getSecond() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
required bytes second = 2;
- getSecond() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
required bytes second = 2;
- getSecond() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPairOrBuilder
-
required bytes second = 2;
- getSecond() - Method in class org.apache.hadoop.hbase.util.Pair
-
Return the second element stored in the pair.
- getSecond() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
Return the second element stored in the pair.
- getSecond() - Method in class org.apache.hadoop.hbase.util.Triple
-
- getSecondPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
optional bytes second_part = 2;
- getSecondPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
optional bytes second_part = 2;
- getSecondPart() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponseOrBuilder
-
optional bytes second_part = 2;
- getSecretKeyForSubject(String, Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Resolves a key for the given subject
- getSecretManager() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- getSelectionTime() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- getSeqid() - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- getSeqNum() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getSeqNumColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for seqNum column for replicaId
- getSeqNumDuringOpen(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
- getSequenceId() - Method in interface org.apache.hadoop.hbase.Cell
-
A region-specific unique monotonically increasing sequence ID given to each Cell.
- getSequenceId() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.KeyValue
-
used to achieve atomic operations in the memstore.
- getSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
required uint64 sequence_id = 2;
- getSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
required uint64 sequence_id = 2;
- getSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceIdOrBuilder
-
required uint64 sequence_id = 2;
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
MemStoreScanner returns max value as sequence id because it will
always have the latest data among all files.
- getSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Do not change this sequence id.
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- getSequenceID() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Get the sequence id associated with this KeyValueScanner.
- getSequenceId() - Method in interface org.apache.hadoop.hbase.regionserver.SequenceId
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReplayHLogKey
-
Returns the original sequence id
- getSequenceId() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getSequenceID() - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- getSequenceId() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getSequenceId(long) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
Wait for sequence number to be assigned & return the assigned value.
- getSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
optional int64 sequence_number = 6;
- getSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
optional int64 sequence_number = 6;
- getSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
-
optional int64 sequence_number = 6;
- getSequenceNumber() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getSerializedComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
optional bytes serialized_comparator = 2;
- getSerializedComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
optional bytes serialized_comparator = 2;
- getSerializedComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ComparatorOrBuilder
-
optional bytes serialized_comparator = 2;
- getSerializedFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
optional bytes serialized_filter = 2;
- getSerializedFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
optional bytes serialized_filter = 2;
- getSerializedFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterOrBuilder
-
optional bytes serialized_filter = 2;
- getSerializedLength() - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Returns the length of the ByteBuffer required to serialized the object.
- getSerializedLength() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getSerializedSize() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getSerializer(Class<KeyValue>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
-
- getSerializer(Class<Mutation>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- getSerializer(Class<Result>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- getServer() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
- getServer() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
- getServer() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerName server = 1;
- getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
required .ServerName server = 1;
- getServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
-
required .ServerName server = 1;
- getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
required .ServerName server = 1;
- getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
required .ServerName server = 1;
- getServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
-
required .ServerName server = 1;
- getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
required .ServerName server = 1;
- getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
required .ServerName server = 1;
- getServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequestOrBuilder
-
required .ServerName server = 1;
- getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required .ServerName server = 1;
- getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
required .ServerName server = 1;
- getServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
-
required .ServerName server = 1;
- getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional .ServerName server = 6;
- getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
optional .ServerName server = 6;
- getServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
optional .ServerName server = 6;
- getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
required .ServerName server = 1;
- getServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
required .ServerName server = 1;
- getServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServerOrBuilder
-
required .ServerName server = 1;
- getServer() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction
-
Get the Server running the transaction or rollback
- getServer() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- getServer() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction
-
Get the Server running the transaction or rollback
- getServer() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- getServerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerName server = 1;
- getServerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
required .ServerName server = 1;
- getServerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
required .ServerName server = 1;
- getServerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required .ServerName server = 1;
- getServerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional .ServerName server = 6;
- getServerBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
required .ServerName server = 1;
- getServerColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for server column for replicaId
- getServerCurrentTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
required uint64 server_current_time = 3;
- getServerCurrentTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
required uint64 server_current_time = 3;
- getServerCurrentTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
-
required uint64 server_current_time = 3;
- getServerHasMoreResults() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Should the client attempt to fetch more results from this region
- getServerInfo() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServerInfo(RpcController, AdminProtos.GetServerInfoRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
-
- getServerInfo(RpcController, AdminProtos.GetServerInfoRequest, RpcCallback<AdminProtos.GetServerInfoResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
rpc GetServerInfo(.GetServerInfoRequest) returns (.GetServerInfoResponse);
- getServerInfo(RpcController, AdminProtos.GetServerInfoRequest, RpcCallback<AdminProtos.GetServerInfoResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
-
rpc GetServerInfo(.GetServerInfoRequest) returns (.GetServerInfoResponse);
- getServerInfo(RpcController, AdminProtos.GetServerInfoRequest, RpcCallback<AdminProtos.GetServerInfoResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
-
- getServerInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
required .ServerInfo server_info = 1;
- getServerInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
required .ServerInfo server_info = 1;
- getServerInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponseOrBuilder
-
required .ServerInfo server_info = 1;
- getServerInfo(RpcController, AdminProtos.AdminService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to get the info of a region server using admin protocol.
- getServerInfo(RpcController, AdminProtos.GetServerInfoRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Get some information of the region server.
- getServerInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
required .ServerInfo server_info = 1;
- getServerInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
required .ServerInfo server_info = 1;
- getServerInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
required .ServerInfo server_info = 1;
- getServerInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponseOrBuilder
-
required .ServerInfo server_info = 1;
- getServerLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerLoad server_load = 2;
- getServerLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
required .ServerLoad server_load = 2;
- getServerLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
-
required .ServerLoad server_load = 2;
- getServerLoadBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerLoad server_load = 2;
- getServerLoadOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerLoad server_load = 2;
- getServerLoadOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
required .ServerLoad server_load = 2;
- getServerLoadOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
-
required .ServerLoad server_load = 2;
- getServerManager() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getServerManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getServerManager() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getServerManager__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getServerName() - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination.OpenRegionDetails
-
- getServerName() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
- getServerName() - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
-
- getServerName() - Method in exception org.apache.hadoop.hbase.exceptions.RegionMovedException
-
- getServerName(Result) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
use MetaTableAccessor methods for interacting with meta layouts
- getServerName() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- getServerName() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
Quote the server name so that users specifying the HOST HTTP header
can't inject attacks.
- getServerName() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getServerName() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get ServerName
- getServerName() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getServerName() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
required .ServerName server_name = 1;
- getServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
required .ServerName server_name = 1;
- getServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfoOrBuilder
-
required .ServerName server_name = 1;
- getServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required .ServerName server_name = 4;
- getServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
required .ServerName server_name = 4;
- getServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
-
required .ServerName server_name = 4;
- getServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
required .ServerName server_name = 2;
- getServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
required .ServerName server_name = 2;
- getServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
-
required .ServerName server_name = 2;
- getServerName() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getServerName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get ServerName
- getServerName() - Method in class org.apache.hadoop.hbase.RegionTransition
-
- getServerName() - Method in interface org.apache.hadoop.hbase.Server
-
- getServerName() - Method in class org.apache.hadoop.hbase.ServerName
-
- getServerName(String, long) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getServerName() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- getServerName() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getServerNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
required .ServerName server_name = 1;
- getServerNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required .ServerName server_name = 4;
- getServerNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
required .ServerName server_name = 2;
- getServerNameFromWALDirectoryName(Configuration, String) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
Pulls a ServerName out of a Path generated according to our layout rules.
- getServerNameFromWALDirectoryName(Path) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
This function returns region server name from a log file name which is in one of the following
formats:
hdfs:///hbase/.logs/-splitting/...
- getServerNameLessStartCode(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
Utility method to excise the start code from a server name
- getServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
required .ServerName server_name = 1;
- getServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
required .ServerName server_name = 1;
- getServerNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfoOrBuilder
-
required .ServerName server_name = 1;
- getServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required .ServerName server_name = 4;
- getServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
required .ServerName server_name = 4;
- getServerNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
-
required .ServerName server_name = 4;
- getServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
required .ServerName server_name = 2;
- getServerNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
required .ServerName server_name = 2;
- getServerNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
-
required .ServerName server_name = 2;
- getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequestOrBuilder
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional .ServerName server = 6;
- getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
optional .ServerName server = 6;
- getServerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
optional .ServerName server = 6;
- getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
required .ServerName server = 1;
- getServerOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServerOrBuilder
-
required .ServerName server = 1;
- getServerPrincipal() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
-
- getServerRegions(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Get a copy of all regions assigned to a server
- getServers() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServers() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getServers() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
-
- getServers__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- getServers__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
-
- getServersSize() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional uint64 serverStartCode = 5;
- getServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
optional uint64 serverStartCode = 5;
- getServerStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
-
optional uint64 serverStartCode = 5;
- getServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
optional uint64 serverStartCode = 2;
- getServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
optional uint64 serverStartCode = 2;
- getServerStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
-
optional uint64 serverStartCode = 2;
- getServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
required uint64 server_start_code = 2;
- getServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
required uint64 server_start_code = 2;
- getServerStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
-
required uint64 server_start_code = 2;
- getServerStartcodeFromServerName(String) - Static method in class org.apache.hadoop.hbase.ServerName
-
- getServerStats(String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Gets the statistics from the given server.
- getServerUserRegions(Connection, ServerName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getServerVersion() - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- getServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string serverVersion = 4;
- getServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string serverVersion = 4;
- getServerVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string serverVersion = 4;
- getServerVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string serverVersion = 4;
- getServerVersionBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string serverVersion = 4;
- getServerVersionBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string serverVersion = 4;
- getService() - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- getService() - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
-
- getService() - Method in interface org.apache.hadoop.hbase.coprocessor.CoprocessorService
-
- getService() - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
-
- getService() - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
-
Just returns a reference to this object, which implements the RowCounterService interface.
- getService() - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- getService() - Method in interface org.apache.hadoop.hbase.coprocessor.SingletonCoprocessorService
-
- getService() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
optional bytes service = 3;
- getService() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
optional bytes service = 3;
- getService() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
-
optional bytes service = 3;
- getService() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional string service = 4;
- getService() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
optional string service = 4;
- getService() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
-
optional string service = 4;
- getService() - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getService() - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- getService() - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- getService() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- getServiceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional string service = 4;
- getServiceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
optional string service = 4;
- getServiceBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
-
optional string service = 4;
- getServiceCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .CoprocessorServiceCall service_call = 4;
- getServiceCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
optional .CoprocessorServiceCall service_call = 4;
- getServiceCall() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
-
optional .CoprocessorServiceCall service_call = 4;
- getServiceCallBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .CoprocessorServiceCall service_call = 4;
- getServiceCallOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .CoprocessorServiceCall service_call = 4;
- getServiceCallOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
optional .CoprocessorServiceCall service_call = 4;
- getServiceCallOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
-
optional .CoprocessorServiceCall service_call = 4;
- getServiceInterface() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface
-
- getServiceName() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
-
- getServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required string service_name = 2;
- getServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
required string service_name = 2;
- getServiceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
-
required string service_name = 2;
- getServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string service_name = 2;
- getServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional string service_name = 2;
- getServiceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional string service_name = 2;
- getServiceNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required string service_name = 2;
- getServiceNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
required string service_name = 2;
- getServiceNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
-
required string service_name = 2;
- getServiceNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string service_name = 2;
- getServiceNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional string service_name = 2;
- getServiceNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional string service_name = 2;
- getServiceResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .CoprocessorServiceResult service_result = 4;
- getServiceResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional .CoprocessorServiceResult service_result = 4;
- getServiceResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional .CoprocessorServiceResult service_result = 4;
- getServiceResultBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .CoprocessorServiceResult service_result = 4;
- getServiceResultOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .CoprocessorServiceResult service_result = 4;
- getServiceResultOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional .CoprocessorServiceResult service_result = 4;
- getServiceResultOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional .CoprocessorServiceResult service_result = 4;
- getServices() - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- getServices() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getServices() - Method in class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- getSessionId() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getSessionPasswd() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getSettingsQualifierForUserNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getSettingsQualifierForUserTable(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getSettingsQualifierRegexForUserNamespace(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getSettingsQualifierRegexForUserTable(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getsFromThrift(List<TGet>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Converts multiple
TGet
s (Thrift) into a list of
Get
s (HBase).
- getShare() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
optional float share = 3;
- getShare() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
optional float share = 3;
- getShare() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuotaOrBuilder
-
optional float share = 3;
- getSharedData() - Method in interface org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment
-
- getSharedStoreFilePercentage() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getSharedStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getShort(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getShort() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getShort(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the short value at index
- getShort() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next short value from this range.
- getShortHistogramReport(Histogram) - Static method in class org.apache.hadoop.hbase.util.YammerHistogramUtils
-
- getShortMidpointKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.KVComparator
-
- getShortMidpointKey(byte[], byte[]) - Method in class org.apache.hadoop.hbase.KeyValue.MetaComparator
-
Don't do any fancy Block Index splitting tricks.
- getShortName() - Method in class org.apache.hadoop.hbase.security.User
-
Returns the shortened version of the user name -- the portion that maps
to an operating system user name.
- getShortNameToLog() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getShortTextFormat(Message) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Return short version of Message toString'd, shorter than TextFormat#shortDebugString.
- getSignature() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
required string signature = 1;
- getSignature() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
required string signature = 1;
- getSignature() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
required string signature = 1;
- getSignatureBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
required string signature = 1;
- getSignatureBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
required string signature = 1;
- getSignatureBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
required string signature = 1;
- getSingleColumnValueFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- getSingleColumnValueFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- getSingleColumnValueFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilterOrBuilder
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- getSingleColumnValueFilterBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- getSingleColumnValueFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- getSingleColumnValueFilterOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- getSingleColumnValueFilterOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilterOrBuilder
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- getSink() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactory
-
- getSink() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl
-
- getSinkMetrics() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Get replication Sink Metrics
- getSize() - Method in class org.apache.hadoop.hbase.io.encoding.EncodedDataBlock
-
Find the size of minimal buffer that could store compressed data.
- getSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- getSize() - Method in interface org.apache.hadoop.hbase.io.hfile.CachedBlock
-
- getSize() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- getSize() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- getSize() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Gets the total size of all StoreFiles in compaction
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getSize() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getSize() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.PlainTextMessageBodyProducer
-
- getSize(ProtobufMessageHandler, Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.ProtobufMessageBodyProducer
-
- getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint32 sizeOfLogQueue = 3;
- getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
required uint32 sizeOfLogQueue = 3;
- getSizeOfLogQueue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
-
required uint32 sizeOfLogQueue = 3;
- getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get the sizeOfLogQueue
- getSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getSizeToCheck(int) - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getSkipBadLines() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
- getSkipReplayedEditsFilter() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- getSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required bool skip_table_state_check = 3;
- getSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
required bool skip_table_state_check = 3;
- getSkipTableStateCheck() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateDataOrBuilder
-
required bool skip_table_state_check = 3;
- getSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required bool skip_table_state_check = 3;
- getSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
required bool skip_table_state_check = 3;
- getSkipTableStateCheck() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateDataOrBuilder
-
required bool skip_table_state_check = 3;
- getSleepInterval() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- getSleepTime() - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- getSmall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool small = 14;
- getSmall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bool small = 14;
- getSmall() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bool small = 14;
- getSmallCompactionQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getSmallCompactionQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
- getSmallCompactionThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getSmallestReadPoint() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getSmallestReadPoint() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getSnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- getSnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
- getSnapshot() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- getSnapshot() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
-
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
required .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequestOrBuilder
-
required .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
optional .ProcedureDescription snapshot = 2;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
optional .ProcedureDescription snapshot = 2;
- getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponseOrBuilder
-
optional .ProcedureDescription snapshot = 2;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
optional .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequestOrBuilder
-
optional .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
optional .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequestOrBuilder
-
optional .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
optional .SnapshotDescription snapshot = 2;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
optional .SnapshotDescription snapshot = 2;
- getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponseOrBuilder
-
optional .SnapshotDescription snapshot = 2;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
required .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequestOrBuilder
-
required .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
required .SnapshotDescription snapshot = 1;
- getSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequestOrBuilder
-
required .SnapshotDescription snapshot = 1;
- getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
optional .ProcedureDescription snapshot = 2;
- getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
optional .SnapshotDescription snapshot = 2;
- getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- getSnapshotBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- getSnapshotDescription() - Method in exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
- getSnapshotDescription() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getSnapshotDescription() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get the SnapshotDescription
- getSnapshotDir() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get the current snapshot working dir
- getSnapshotList(Configuration) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the list of available snapshots in the specified location
- getSnapshotManagerForTesting() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Exposed for TESTING!
- getSnapShotOfAssignment(Collection<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
required .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequestOrBuilder
-
required .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
optional .ProcedureDescription snapshot = 2;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
optional .ProcedureDescription snapshot = 2;
- getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponseOrBuilder
-
optional .ProcedureDescription snapshot = 2;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
optional .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequestOrBuilder
-
optional .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
optional .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequestOrBuilder
-
optional .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
optional .SnapshotDescription snapshot = 2;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
optional .SnapshotDescription snapshot = 2;
- getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponseOrBuilder
-
optional .SnapshotDescription snapshot = 2;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
required .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequestOrBuilder
-
required .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
required .SnapshotDescription snapshot = 1;
- getSnapshotOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequestOrBuilder
-
required .SnapshotDescription snapshot = 1;
- getSnapshotRootDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the snapshot root directory.
- getSnapshots(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshots(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshots(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponseOrBuilder
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponseOrBuilder
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- getSnapshotSize() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- getSnapshotSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getSnapshotSize() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Return the size of the snapshot(s) if any
- getSnapshotSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the memstore snapshot size
- getSnapshotsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponseOrBuilder
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponseOrBuilder
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponseOrBuilder
-
repeated .SnapshotDescription snapshots = 1;
- getSnapshotStats(Configuration, HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
Returns the snapshot stats
- getSocketAddress() - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getSoftLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
optional uint64 soft_limit = 2;
- getSoftLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
optional uint64 soft_limit = 2;
- getSoftLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuotaOrBuilder
-
optional uint64 soft_limit = 2;
- getSortedColumns() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getSortedColumnsIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getSortedColumnsSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- getSortedIndexForInsertionId(int) - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
-
- getSortedPrefixes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
repeated bytes sorted_prefixes = 1;
- getSortedPrefixes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
repeated bytes sorted_prefixes = 1;
- getSortedPrefixes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilterOrBuilder
-
repeated bytes sorted_prefixes = 1;
- getSortedPrefixesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
repeated bytes sorted_prefixes = 1;
- getSortedPrefixesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
repeated bytes sorted_prefixes = 1;
- getSortedPrefixesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilterOrBuilder
-
repeated bytes sorted_prefixes = 1;
- getSortedPrefixesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
repeated bytes sorted_prefixes = 1;
- getSortedPrefixesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
repeated bytes sorted_prefixes = 1;
- getSortedPrefixesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilterOrBuilder
-
repeated bytes sorted_prefixes = 1;
- getSortedRanges() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
-
get/set
- getSortedUniqueTimestamps() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
- getSource() - Method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
- getSource() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Get the source server for the plan for this region.
- getSource() - Method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
-
- getSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional string source = 1;
- getSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
optional string source = 1;
- getSource() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
-
optional string source = 1;
- getSource(String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactory
-
- getSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceFactoryImpl
-
- getSource() - Method in class org.apache.hadoop.hbase.rest.MetricsREST
-
- getSource() - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- getSourceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional string source = 1;
- getSourceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
optional string source = 1;
- getSourceBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
-
optional string source = 1;
- getSourceMetrics() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Get Replication Source Metrics
- getSourceName() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getSources() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a list of all the normal sources of this rs
- getSpec() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionSpecifier spec = 1;
- getSpec() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
required .RegionSpecifier spec = 1;
- getSpec() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
-
required .RegionSpecifier spec = 1;
- getSpecBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionSpecifier spec = 1;
- getSpecOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionSpecifier spec = 1;
- getSpecOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
required .RegionSpecifier spec = 1;
- getSpecOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
-
required .RegionSpecifier spec = 1;
- getSplit() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bool split = 6;
- getSplit() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
optional bool split = 6;
- getSplit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
optional bool split = 6;
- getSplitCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getSplitEditFilesSorted(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Returns sorted set of edit files made by splitter, excluding files
with '.temp' suffix.
- getSplitKey() - Method in class org.apache.hadoop.hbase.io.Reference
-
- getSplitKey(byte[], byte[], boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
select a split point in the region.
- getSplitkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
required bytes splitkey = 1;
- getSplitkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
required bytes splitkey = 1;
- getSplitkey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.ReferenceOrBuilder
-
required bytes splitkey = 1;
- getSplitKeys(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
repeated bytes split_keys = 2;
- getSplitKeys(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
repeated bytes split_keys = 2;
- getSplitKeys(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequestOrBuilder
-
repeated bytes split_keys = 2;
- getSplitKeysArray(MasterProtos.CreateTableRequest) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
get the split keys in form "byte [][]" from a CreateTableRequest proto
- getSplitKeysCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
repeated bytes split_keys = 2;
- getSplitKeysCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
repeated bytes split_keys = 2;
- getSplitKeysCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequestOrBuilder
-
repeated bytes split_keys = 2;
- getSplitKeysList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
repeated bytes split_keys = 2;
- getSplitKeysList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
repeated bytes split_keys = 2;
- getSplitKeysList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequestOrBuilder
-
repeated bytes split_keys = 2;
- getSplitLogDir(Path, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- getSplitLogDirTmpComponent(String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- getSplitLogManagerCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
Method to retrieve coordination for split log manager
- getSplitLogManagerCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getSplitLogWorkerCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
Method to retrieve coordination for split log worker
- getSplitLogWorkerCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getSplitPartSize() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
optional bytes split_point = 2;
- getSplitPoint() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
optional bytes split_point = 2;
- getSplitPoint() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequestOrBuilder
-
optional bytes split_point = 2;
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
-
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- getSplitPoint() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Determines if Store should be split
- getSplitPoint() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets the split point for the split of this set of store files (approx.
- getSplitPoint() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getSplitPolicy() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getSplitPolicyClass(HTableDescriptor, Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- getSplitQueueSize() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getSplitQueueSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of the split queue
- getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobConf, int) - Method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
Deprecated.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Calculates the splits that will serve as input for the map tasks.
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
- getSplits(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
- getSplits(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- getSplits() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
- getSplitSize() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getSplitThreadNum() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- getSplitTransactionCoordination() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
Method to retrieve coordination for split transaction.
- getSplitTransactionCoordination() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getSrcChecksum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string src_checksum = 6;
- getSrcChecksum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string src_checksum = 6;
- getSrcChecksum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string src_checksum = 6;
- getSrcChecksum() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the checksum of the source files from which Hadoop was compiled.
- getSrcChecksumBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string src_checksum = 6;
- getSrcChecksumBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string src_checksum = 6;
- getSrcChecksumBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string src_checksum = 6;
- getStackId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
repeated uint32 stack_id = 7;
- getStackId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
repeated uint32 stack_id = 7;
- getStackId(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
repeated uint32 stack_id = 7;
- getStackIdCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
repeated uint32 stack_id = 7;
- getStackIdCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
repeated uint32 stack_id = 7;
- getStackIdCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
repeated uint32 stack_id = 7;
- getStackIdList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
repeated uint32 stack_id = 7;
- getStackIdList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
repeated uint32 stack_id = 7;
- getStackIdList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
repeated uint32 stack_id = 7;
- getStackIndexes() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getStackTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string stack_trace = 2;
- getStackTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional string stack_trace = 2;
- getStackTrace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional string stack_trace = 2;
- getStackTraceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string stack_trace = 2;
- getStackTraceBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional string stack_trace = 2;
- getStackTraceBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional string stack_trace = 2;
- getStagingDir(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.JobUtil
-
Initializes the staging directory and returns the path.
- getStagingPath(String, byte[]) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
-
- getStagingPath(Configuration, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
-
This returns the staging path for a given column family.
- getStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional bool stale = 4 [default = false];
- getStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
optional bool stale = 4 [default = false];
- getStale() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
optional bool stale = 4 [default = false];
- getStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool stale = 6;
- getStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
optional bool stale = 6;
- getStale() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
optional bool stale = 6;
- getStamp() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getStamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
optional uint64 stamp = 3;
- getStamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
optional uint64 stamp = 3;
- getStamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
-
optional uint64 stamp = 3;
- getStart() - Method in exception org.apache.hadoop.hbase.errorhandling.TimeoutException
-
- getStart() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- getStartAndPrefix() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
the prefix (and thus start row) of the keys you want
- getStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
optional uint64 start_code = 3;
- getStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
optional uint64 start_code = 3;
- getStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
-
optional uint64 start_code = 3;
- getStartcode() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getStartCode() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get HRegionServer start time
- getStartCode() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- getStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int64 startCode = 2;
- getStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
optional int64 startCode = 2;
- getStartCode() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
optional int64 startCode = 2;
- getStartcode() - Method in class org.apache.hadoop.hbase.ServerName
-
- getStartCodeColumn(int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Returns the column qualifier for server start code column for replicaId
- getStartDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
required string start_date = 1;
- getStartDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
required string start_date = 1;
- getStartDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUpOrBuilder
-
required string start_date = 1;
- getStartDateBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
required string start_date = 1;
- getStartDateBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
required string start_date = 1;
- getStartDateBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUpOrBuilder
-
required string start_date = 1;
- getStartEndKeys() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
Gets the starting and ending row keys for every region in the currently
open table.
- getStartEndKeys() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getStartEndKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the starting and ending row keys for every region in the currently
open table.
- getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
- getStartEndKeys() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- getStartId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
required uint64 start_id = 1;
- getStartId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
required uint64 start_id = 1;
- getStartId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNodeOrBuilder
-
required uint64 start_id = 1;
- getStartKey(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Gets the start key from the specified region name.
- getStartKey() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getStartKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bytes start_key = 3;
- getStartKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
optional bytes start_key = 3;
- getStartKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
optional bytes start_key = 3;
- getStartKey() - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- getStartKey() - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- getStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional bytes startKey = 2;
- getStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
optional bytes startKey = 2;
- getStartKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
optional bytes startKey = 2;
- getStartKey() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getStartKey() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getStartKey() - Method in interface org.apache.hadoop.hbase.util.KeyRange
-
- getStartKeys() - Method in class org.apache.hadoop.hbase.client.HRegionLocator
-
Gets the starting row key for every region in the currently open table.
- getStartKeys() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getStartKeys() - Method in interface org.apache.hadoop.hbase.client.RegionLocator
-
Gets the starting row key for every region in the currently open table.
- getStartRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getStartRow() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- getStartRow() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getStartRow() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the start row.
- getStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bytes start_row = 3;
- getStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bytes start_row = 3;
- getStartRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bytes start_row = 3;
- getStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bytes start_row = 1;
- getStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
optional bytes start_row = 1;
- getStartRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRangeOrBuilder
-
optional bytes start_row = 1;
- getStartRow(int) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
Gets the start row for a given stripe.
- getStartRow(int) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStartRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional bytes startRow = 1;
- getStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional bytes startRow = 1;
- getStartRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional bytes startRow = 1;
- getStartRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Starting row in table to scan.
- getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Starting row in table to scan.
- getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Starting row in table to scan.
- getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Starting row in table to scan.
- getStartRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getStartRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getStartRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bool start_row_inclusive = 2;
- getStartRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
optional bool start_row_inclusive = 2;
- getStartRowInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRangeOrBuilder
-
optional bool start_row_inclusive = 2;
- getStarts() - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
- getStartTime() - Method in class org.apache.hadoop.hbase.ipc.AsyncCall
-
Get the start time
- getStartTime() - Method in class org.apache.hadoop.hbase.ipc.Call
-
- getStartTime() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get hbase master start time
- getStartTime() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getStartTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStartTime() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getStartTime() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- getStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional uint64 start_time = 2;
- getStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
optional uint64 start_time = 2;
- getStartTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
-
optional uint64 start_time = 2;
- getStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required uint64 start_time = 4;
- getStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
required uint64 start_time = 4;
- getStartTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
required uint64 start_time = 4;
- getStartTime() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- getStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int64 startTime = 5;
- getStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional int64 startTime = 5;
- getStartTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional int64 startTime = 5;
- getStartTime() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getState() - Method in class org.apache.hadoop.hbase.master.RegionState
-
- getState() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getState() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getState(int) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Convert an ordinal (or state id) to an Enum (or more descriptive) state object.
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
required .RegionState.State state = 2;
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
required .RegionState.State state = 2;
- getState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
-
required .RegionState.State state = 2;
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
required .GetProcedureResultResponse.State state = 1;
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
required .GetProcedureResultResponse.State state = 1;
- getState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
-
required .GetProcedureResultResponse.State state = 1;
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required .ProcedureState state = 6;
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
required .ProcedureState state = 6;
- getState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
required .ProcedureState state = 6;
- getState(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
repeated uint32 state = 1;
- getState(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
repeated uint32 state = 1;
- getState(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureDataOrBuilder
-
repeated uint32 state = 1;
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
optional .RegionState.State state = 3;
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
optional .RegionState.State state = 3;
- getState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServerOrBuilder
-
optional .RegionState.State state = 3;
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
-
required .ReplicationState.State state = 1;
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
required .ReplicationState.State state = 1;
- getState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationStateOrBuilder
-
required .ReplicationState.State state = 1;
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
required .SplitLogTask.State state = 1;
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
required .SplitLogTask.State state = 1;
- getState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
-
required .SplitLogTask.State state = 1;
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
-
required .Table.State state = 1 [default = ENABLED];
- getState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
required .Table.State state = 1 [default = ENABLED];
- getState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableOrBuilder
-
required .Table.State state = 1 [default = ENABLED];
- getState() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getStateCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
repeated uint32 state = 1;
- getStateCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
repeated uint32 state = 1;
- getStateCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureDataOrBuilder
-
repeated uint32 state = 1;
- getStateData() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional bytes state_data = 12;
- getStateData() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional bytes state_data = 12;
- getStateData() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional bytes state_data = 12;
- getStateId(MasterProcedureProtos.AddColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- getStateId(MasterProcedureProtos.CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getStateId(MasterProcedureProtos.DeleteColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- getStateId(MasterProcedureProtos.DeleteTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getStateId(MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getStateId(MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getStateId(MasterProcedureProtos.ModifyColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- getStateId(MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getStateId(MasterProcedureProtos.TruncateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getStateId(TState) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Convert the Enum (or more descriptive) state object to an ordinal (or state id).
- getStateList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
repeated uint32 state = 1;
- getStateList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
repeated uint32 state = 1;
- getStateList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureDataOrBuilder
-
repeated uint32 state = 1;
- getStateTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStatisticsTracker() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- getStats() - Method in class org.apache.hadoop.hbase.client.Result
-
- getStats(ServerName) - Method in class org.apache.hadoop.hbase.client.ServerStatisticTracker
-
- getStats() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Get the statistics for this block cache.
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
Get counter statistics for this cache.
- getStats() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- getStats() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEditsReplaySink
-
Get a string representation of this sink's metrics
- getStats() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
Get a string representation of this sink's metrics
- getStats() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- getStats() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Get a string representation of the current statistics
for this source
- getStats() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a string representation of all the sources' metrics
- getStatsForRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.backoff.ServerStatistics
-
- getStatus() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Gets the status of this handler; if it is currently servicing an RPC,
this status will include the RPC information.
- getStatus() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStatus() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- getStatusOfPeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Get the replication status for the specified connected remote slave cluster.
- getStatusOfPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getStatusOfPeerFromBackingStore(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Get the replication status for the specified remote slave cluster, which doesn't
have to be connected.
- getStatusOfPeerFromBackingStore(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getStatusTime() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- getStd(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives a Pair with first object a List containing Sum and sum of squares,
and the second object as row count.
- getStd(RpcController, AggregateProtos.AggregateRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
-
- getStd(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
rpc GetStd(.AggregateRequest) returns (.AggregateResponse);
- getStd(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
-
rpc GetStd(.AggregateRequest) returns (.AggregateResponse);
- getStd(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
-
- getStdDev() - Method in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
-
- getStopper() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getStopRow() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getStopRow() - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter.RowRange
-
- getStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bytes stop_row = 4;
- getStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bytes stop_row = 4;
- getStopRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bytes stop_row = 4;
- getStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bytes stop_row = 3;
- getStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
optional bytes stop_row = 3;
- getStopRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRangeOrBuilder
-
optional bytes stop_row = 3;
- getStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
row to stop scanning on.
- getStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
row to stop scanning on.
- getStopRow() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getStopRow() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getStopRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bool stop_row_inclusive = 4;
- getStopRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
optional bool stop_row_inclusive = 4;
- getStopRowInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRangeOrBuilder
-
optional bool stop_row_inclusive = 4;
- getStopRowKey() - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
-
- getStopRowKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
-
optional bytes stop_row_key = 1;
- getStopRowKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
optional bytes stop_row_key = 1;
- getStopRowKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilterOrBuilder
-
optional bytes stop_row_key = 1;
- getStore() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- getStore(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStore(byte[]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return the Store for the given family
- getStoreArchivePath(Configuration, TableName, String, String) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the directory to archive a store directory
- getStoreArchivePath(Configuration, HRegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the directory to archive a store directory
- getStoreCompactionPriority() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
- getStoreCompactionPriority() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStoreCompleteSequenceId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceId(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceId() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStoreCompleteSequenceIdBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreCompleteSequenceIdOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- getStoreDir(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the directory path of the specified family
- getStoreEngine() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Returns the StoreEngine that is backing this concrete implementation of Store.
- getStoreFile(RpcController, AdminProtos.GetStoreFileRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
-
- getStoreFile(RpcController, AdminProtos.GetStoreFileRequest, RpcCallback<AdminProtos.GetStoreFileResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
rpc GetStoreFile(.GetStoreFileRequest) returns (.GetStoreFileResponse);
- getStoreFile(RpcController, AdminProtos.GetStoreFileRequest, RpcCallback<AdminProtos.GetStoreFileResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
-
rpc GetStoreFile(.GetStoreFileRequest) returns (.GetStoreFileResponse);
- getStoreFile(RpcController, AdminProtos.GetStoreFileRequest, RpcCallback<AdminProtos.GetStoreFileResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
-
- getStoreFile(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
repeated string store_file = 1;
- getStoreFile(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
repeated string store_file = 1;
- getStoreFile(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponseOrBuilder
-
repeated string store_file = 1;
- getStoreFile(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
repeated string store_file = 3;
- getStoreFile(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
repeated string store_file = 3;
- getStoreFile(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptorOrBuilder
-
repeated string store_file = 3;
- getStoreFile(RpcController, AdminProtos.GetStoreFileRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
- getStoreFileBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
repeated string store_file = 1;
- getStoreFileBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
repeated string store_file = 1;
- getStoreFileBytes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponseOrBuilder
-
repeated string store_file = 1;
- getStoreFileBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
repeated string store_file = 3;
- getStoreFileBytes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
repeated string store_file = 3;
- getStoreFileBytes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptorOrBuilder
-
repeated string store_file = 3;
- getStoreFileCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
repeated string store_file = 1;
- getStoreFileCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
repeated string store_file = 1;
- getStoreFileCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponseOrBuilder
-
repeated string store_file = 1;
- getStoreFileCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
repeated string store_file = 3;
- getStoreFileCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
repeated string store_file = 3;
- getStoreFileCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptorOrBuilder
-
repeated string store_file = 3;
- getStorefileCount() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Returns the number of files currently in use.
- getStorefileCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStoreFileIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the Size (in bytes) of indexes in storefiles on disk.
- getStorefileIndexSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 storefile_index_size_MB = 7;
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 storefile_index_size_MB = 7;
- getStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 storefile_index_size_MB = 7;
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 storefileIndexSizeMB = 6;
- getStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 storefileIndexSizeMB = 6;
- getStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 storefileIndexSizeMB = 6;
- getStoreFileInfo(Configuration, FileSystem, HRegionInfo, HRegionInfo, String, Path) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns a StoreFileInfo from the given FileStatus.
- getStoreFileList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
repeated string store_file = 1;
- getStoreFileList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
repeated string store_file = 1;
- getStoreFileList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponseOrBuilder
-
repeated string store_file = 1;
- getStoreFileList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
repeated string store_file = 3;
- getStoreFileList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
repeated string store_file = 3;
- getStoreFileList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptorOrBuilder
-
repeated string store_file = 3;
- getStoreFileList(byte[][]) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStoreFileList(byte[][]) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getStoreFileManager() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- getStoreFileOpenAndCloseThreadPool(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 storefiles = 3;
- getStorefiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 storefiles = 3;
- getStorefiles() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 storefiles = 3;
- getStoreFiles(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFiles(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFiles(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFilesOrBuilder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFiles(AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to get the list of files of a column family
on a given region using admin protocol.
- getStoreFiles(RpcController, AdminProtos.AdminService.BlockingInterface, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to get the list of files of a column family
on a given region using admin protocol.
- getStorefiles() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStorefiles() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
- getStoreFiles(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the store files available for the family.
- getStoreFiles(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getStoreFiles(String, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns the store files available for the family.
- getStorefiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStorefiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getStorefiles() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Gets the snapshot of the store files currently in use.
- getStorefiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 storefiles = 3;
- getStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 storefiles = 3;
- getStorefiles() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 storefiles = 3;
- getStorefiles() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStoreFilesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFilesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFileScanner(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
Get a scanner to scan over this StoreFile.
- getStoreFileScanner(boolean, boolean, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
Get a scanner to scan over this StoreFile.
- getStoreFilesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFilesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFilesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFilesOrBuilder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStorefilesCount() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStorefilesCount() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getStoreFilesCount() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getStorefilesIndexSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStorefilesIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getStoreFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total size of the store files this region server is serving from.
- getStoreFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the total size of the store files this region server is serving from.
- getStoreFileSize() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getStorefileSizeInMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 storefile_size_MB = 5;
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 storefile_size_MB = 5;
- getStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 storefile_size_MB = 5;
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 storefileSizeMB = 4;
- getStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 storefileSizeMB = 4;
- getStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 storefileSizeMB = 4;
- getStoreFilesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFilesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFilesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFilesOrBuilder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFilesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFilesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFilesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFilesOrBuilder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFilesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFilesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStoreFilesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFilesOrBuilder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- getStorefilesSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStorefilesSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getStoreFilesSize() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
-
- getStoreFileTtl() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStoreFileTtl() - Method in interface org.apache.hadoop.hbase.regionserver.StoreConfigInformation
-
- getStoreFlusher() - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- getStoreFlushes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushes(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushes(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreFlushesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- getStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required string store_home_dir = 6;
- getStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
required string store_home_dir = 6;
- getStoreHomeDir() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
required string store_home_dir = 6;
- getStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
required string store_home_dir = 2;
- getStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
required string store_home_dir = 2;
- getStoreHomeDir() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptorOrBuilder
-
required string store_home_dir = 2;
- getStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
required string store_home_dir = 2;
- getStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
required string store_home_dir = 2;
- getStoreHomeDir() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptorOrBuilder
-
required string store_home_dir = 2;
- getStoreHomedir(Path, HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
-
Deprecated.
- getStoreHomedir(Path, String, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.HStore
-
Deprecated.
- getStoreHomeDirBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required string store_home_dir = 6;
- getStoreHomeDirBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
required string store_home_dir = 6;
- getStoreHomeDirBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
required string store_home_dir = 6;
- getStoreHomeDirBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
required string store_home_dir = 2;
- getStoreHomeDirBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
required string store_home_dir = 2;
- getStoreHomeDirBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptorOrBuilder
-
required string store_home_dir = 2;
- getStoreHomeDirBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
required string store_home_dir = 2;
- getStoreHomeDirBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
required string store_home_dir = 2;
- getStoreHomeDirBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptorOrBuilder
-
required string store_home_dir = 2;
- getStoreLastFlushedSequenceId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceId(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponseOrBuilder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponseOrBuilder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponseOrBuilder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponseOrBuilder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLastFlushedSequenceIdOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponseOrBuilder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- getStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional uint32 store_limit = 8;
- getStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional uint32 store_limit = 8;
- getStoreLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional uint32 store_limit = 8;
- getStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 store_limit = 11;
- getStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional uint32 store_limit = 11;
- getStoreLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional uint32 store_limit = 11;
- getStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional uint32 store_offset = 9;
- getStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional uint32 store_offset = 9;
- getStoreOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional uint32 store_offset = 9;
- getStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 store_offset = 12;
- getStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional uint32 store_offset = 12;
- getStoreOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional uint32 store_offset = 12;
- getStoreOpenAndCloseThreadPool(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 stores = 2;
- getStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 stores = 2;
- getStores() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 stores = 2;
- getStores(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- getStores(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
repeated .StoreDescriptor stores = 3;
- getStores(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
-
repeated .StoreDescriptor stores = 3;
- getStores(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- getStores(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
repeated .StoreDescriptor stores = 5;
- getStores(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
repeated .StoreDescriptor stores = 5;
- getStores() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStores() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getStores() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Return the list of Stores managed by this region
- getStores() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 stores = 2;
- getStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 stores = 2;
- getStores() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 stores = 2;
- getStores() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStoresBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- getStoresBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- getStoresBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- getStoresBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- getStoresCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- getStoresCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
repeated .StoreDescriptor stores = 3;
- getStoresCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
-
repeated .StoreDescriptor stores = 3;
- getStoresCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- getStoresCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
repeated .StoreDescriptor stores = 5;
- getStoresCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
repeated .StoreDescriptor stores = 5;
- getStoreSequenceId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceId(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIdsOrBuilder
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIdsOrBuilder
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIdsOrBuilder
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIdsOrBuilder
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSequenceIdOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIdsOrBuilder
-
repeated .StoreSequenceId store_sequence_id = 2;
- getStoreSizeUncompressed() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getStoreSizeUncompressed() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getStoresList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- getStoresList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
repeated .StoreDescriptor stores = 3;
- getStoresList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
-
repeated .StoreDescriptor stores = 3;
- getStoresList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- getStoresList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
repeated .StoreDescriptor stores = 5;
- getStoresList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
repeated .StoreDescriptor stores = 5;
- getStoresOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- getStoresOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
repeated .StoreDescriptor stores = 3;
- getStoresOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
-
repeated .StoreDescriptor stores = 3;
- getStoresOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- getStoresOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
repeated .StoreDescriptor stores = 5;
- getStoresOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
repeated .StoreDescriptor stores = 5;
- getStoresOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- getStoresOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
repeated .StoreDescriptor stores = 3;
- getStoresOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
-
repeated .StoreDescriptor stores = 3;
- getStoresOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- getStoresOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
repeated .StoreDescriptor stores = 5;
- getStoresOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
repeated .StoreDescriptor stores = 5;
- getStoreTracker() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 store_uncompressed_size_MB = 4;
- getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 store_uncompressed_size_MB = 4;
- getStoreUncompressedSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 store_uncompressed_size_MB = 4;
- getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getStream(boolean) - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
Get the stream to use.
- getStream() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
- getStream() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- getStream() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
Gets the input stream instance.
- getStripeBoundaries() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
- getStripeBoundaries() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStripeCompactMaxFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getStripeCompactMinFiles() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- getStripeCount() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
- getStripeCount() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStripes() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeInformationProvider
-
- getStripes() - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getStructDesc() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- getStructuralString() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- getStub() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getSubstr() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
required string substr = 1;
- getSubstr() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
required string substr = 1;
- getSubstr() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparatorOrBuilder
-
required string substr = 1;
- getSubstrBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
required string substr = 1;
- getSubstrBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
required string substr = 1;
- getSubstrBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparatorOrBuilder
-
required string substr = 1;
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- getSuccess() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- getSuccessfulCoalescings() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getSuccessfulCoalescings() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- getSuccessIterator() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- getSuccessSize() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- getSum(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Gives the sum for a given combination of column qualifier and column
family, in the given row range as defined in the Scan object.
- getSum(RpcController, AggregateProtos.AggregateRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.BlockingInterface
-
- getSum(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
rpc GetSum(.AggregateRequest) returns (.AggregateResponse);
- getSum(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Interface
-
rpc GetSum(.AggregateRequest) returns (.AggregateResponse);
- getSum(RpcController, AggregateProtos.AggregateRequest, RpcCallback<AggregateProtos.AggregateResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService.Stub
-
- getSumHitCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getSumHitCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getSumHitCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getSumHitCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getSumRequestCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getSumRequestCachingCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getSumRequestCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- getSumRequestCountsPastNPeriods() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache.CombinedCacheStats
-
- getSupportedAlgorithms() - Static method in class org.apache.hadoop.hbase.io.compress.Compression
-
Get names of supported compression algorithms.
- getSupportedCiphers() - Method in interface org.apache.hadoop.hbase.io.crypto.CipherProvider
-
Return the set of Ciphers supported by this provider
- getSupportedCiphers() - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- getSupportedCiphers() - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get names of supported encryption algorithms
- getSupportedCiphers(Configuration) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Get names of supported encryption algorithms
- getSupportedCompressionAlgorithms() - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Get names of supported compression algorithms.
- getSupportedFilters() - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Return a Set of filters supported by the Filter Language
- getSynchronous() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
optional bool synchronous = 2;
- getSynchronous() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
optional bool synchronous = 2;
- getSynchronous() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequestOrBuilder
-
optional bool synchronous = 2;
- getSystemLoadAverage() - Method in class org.apache.hadoop.hbase.util.JVM
-
- getSystemUser() - Static method in class org.apache.hadoop.hbase.security.Superusers
-
- getTable() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a Table implementation for accessing a table.
- getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.Connection
-
Retrieve a Table implementation for accessing a table.
- getTable(String) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
- getTable(byte[]) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
- getTable(TableName) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
- getTable(String, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
- getTable(byte[], ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
- getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Retrieve an HTableInterface implementation for access to a table.
- getTable(String) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Get a reference to the specified table from the pool.
- getTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Get a reference to the specified table from the pool.
- getTable(TableName) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Open a table from within the Coprocessor environment
- getTable(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Open a table from within the Coprocessor environment
- getTable(TableName) - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getTable(TableName, ExecutorService) - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getTable(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Gets the table name from the specified region name.
- getTable() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Get current table name of the region
- getTable() - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Allows subclasses to get the
Table
.
- getTable() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Allows subclasses to get the
Table
.
- getTable() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the table name.
- getTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional string table = 2;
- getTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
optional string table = 2;
- getTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
optional string table = 2;
- getTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .TableSchema table = 3;
- getTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
optional .TableSchema table = 3;
- getTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplitOrBuilder
-
optional .TableSchema table = 3;
- getTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- getTable() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- getTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Creates and returns a Table instance from a given table name.
- getTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
the table to append the value on
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
to check in and delete from
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
to check in and put to
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
the table to delete from
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
the table to delete from
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
the table to check on
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
the table to get from
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
the table to get from
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
the table to get the Scanner for
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
the table to increment the value on
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
table to apply the mutations
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
the table to get the Scanner for
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
the table to put data in
- getTable() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
the table to put data in
- getTable(String) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Caller closes the table afterwards.
- getTableArchivePath(Path, TableName) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the path to the table archive directory based on the configured archive directory.
- getTableArchivePath(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveUtil
-
Get the path to the table archive directory based on the configured archive directory.
- getTableBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .TableSchema table = 3;
- getTableBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional string table = 2;
- getTableBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
optional string table = 2;
- getTableBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
optional string table = 2;
- getTableCFs() - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeer
-
Get replicable (table, cf-list) map of this peer
- getTableCFs(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Get the table and column-family-list map of the peer.
- getTableCFs(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- getTableCFs() - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
Get replicable (table, cf-list) map of this peer
- getTableCfWALEntryFilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
Returns a WALEntryFilter for checking replication per table and CF.
- getTableDesc() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getTableDesc() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getTableDescriptor(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Method for getting the tableDescriptor
- getTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Method for getting the tableDescriptor
- getTableDescriptor(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTable
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getTableDescriptor() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
Gets a TableDescriptor from the masterServices.
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- getTableDescriptor() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Get the table descriptor from the Snapshot
- getTableDescriptorFromFs(FileSystem, Path, TableName) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns the latest table descriptor for the given table directly from the file system
if it exists, bypassing the local cache.
- getTableDescriptorFromFs(FileSystem, Path, TableName, boolean) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns the latest table descriptor for the table located at the given directory
directly from the file system if it exists.
- getTableDescriptorFromFs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns the latest table descriptor for the table located at the given directory
directly from the file system if it exists.
- getTableDescriptorFromFs(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Returns the latest table descriptor for the table located at the given directory
directly from the file system if it exists.
- getTableDescriptors(List<String>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get tableDescriptors
- getTableDescriptors(List<String>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get tableDescriptors
- getTableDescriptors() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getTableDescriptors(RpcController, MasterProtos.GetTableDescriptorsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Get list of TableDescriptors for requested tables.
- getTableDescriptors() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getTableDescriptors(RpcController, MasterProtos.GetTableDescriptorsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- getTableDescriptors(RpcController, MasterProtos.GetTableDescriptorsRequest, RpcCallback<MasterProtos.GetTableDescriptorsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc GetTableDescriptors(.GetTableDescriptorsRequest) returns (.GetTableDescriptorsResponse);
- getTableDescriptors(RpcController, MasterProtos.GetTableDescriptorsRequest, RpcCallback<MasterProtos.GetTableDescriptorsResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc GetTableDescriptors(.GetTableDescriptorsRequest) returns (.GetTableDescriptorsResponse);
- getTableDescriptors(RpcController, MasterProtos.GetTableDescriptorsRequest, RpcCallback<MasterProtos.GetTableDescriptorsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- getTableDescriptors() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getTableDescriptors() - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- getTableDescriptorsByTableName(List<TableName>) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get tableDescriptors
- getTableDescriptorsByTableName(List<TableName>) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Get tableDescriptors
- getTableDir(Path, byte[]) - Static method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- getTableDir() - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
- getTableDir(Path, TableName) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the Path
object representing the table directory under
path rootdir
- getTableDirs(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- getTableFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
- getTableFragmentation(HMaster) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and checks how many stores for each table
have more than one file in them.
- getTableFragmentation(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and checks how many stores for each table
have more than one file in them.
- getTableFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getTableInfo() - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
- getTableInfo() - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
- getTableInfoPath(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Find the most current table info file for the table located in the given table directory.
- getTableLimiter(TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified table.
- getTableLimiter(TableName) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Return the limiter for the specified table associated with this quota.
- getTableList() - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
- getTableLockManager() - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
- getTableLockManager() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getTableLockManager() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.HTable
-
Gets the name of this table.
- getTableName() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getTableName() - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- getTableName(byte[]) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
- getTableName() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- getTableName() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Get the name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- getTableName() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
Returns the table name converted to a byte array.
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getTableName() - Method in interface org.apache.hadoop.hbase.master.procedure.TableProcedureInterface
-
- getTableName() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
optional .TableName table_name = 2;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequestOrBuilder
-
optional .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
optional .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
-
optional .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
required .TableName table_name = 2;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
optional .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
optional .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
optional .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
required .TableName table_name = 2;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
required .TableName table_name = 2;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
required .TableName table_name = 2;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
required .TableName table_name = 2;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateDataOrBuilder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
required .TableName table_name = 2;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateDataOrBuilder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
required .TableName table_name = 2;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
-
required .TableName table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableName table_name = 3;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
optional .TableName table_name = 3;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
optional .TableName table_name = 3;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
required .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequestOrBuilder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
required .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequestOrBuilder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
required .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequestOrBuilder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
required .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequestOrBuilder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
required .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequestOrBuilder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
required .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequestOrBuilder
-
required .TableName table_name = 1;
- getTableName(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- getTableName(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
repeated .TableName tableName = 1;
- getTableName(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponseOrBuilder
-
repeated .TableName tableName = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
required .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequestOrBuilder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
required .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequestOrBuilder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
required .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequestOrBuilder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .TableName table_name = 4;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional .TableName table_name = 4;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional .TableName table_name = 4;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
required .TableName tableName = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
required .TableName tableName = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequestOrBuilder
-
required .TableName tableName = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
required .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequestOrBuilder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
required .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
-
required .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required bytes table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
required bytes table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
required bytes table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
required bytes table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
required bytes table_name = 2;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
required bytes table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
required bytes table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
required bytes table_name = 2;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
required bytes table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required bytes table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
required bytes table_name = 2;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
required bytes table_name = 2;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional .TableName table_name = 1;
- getTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional .TableName table_name = 1;
- getTableName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the name of the table the region belongs to.
- getTableName() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getTableName() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- getTableName() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getTableName() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getTableName() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
name of table to create
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
name of table to delete
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
table name
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
name of the table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
table name
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
name of the table to check
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
name of table
- getTableName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
name of table
- getTableName(Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the
TableName
object representing
the table directory under
path rootdir
- getTableName() - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- getTablename() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getTableName() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
-
- getTableNameArray(List<HBaseProtos.TableName>) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional .TableName table_name = 2;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional .TableName table_name = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
required .TableName table_name = 2;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
optional .TableName table_name = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .TableName table_name = 2;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .TableName table_name = 2;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .TableName table_name = 2;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableName table_name = 3;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .TableName table_name = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
required .TableName table_name = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
required .TableName table_name = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
required .TableName table_name = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
required .TableName table_name = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
required .TableName table_name = 1;
- getTableNameBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
required .TableName table_name = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .TableName table_name = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableName table_name = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .TableName table_name = 4;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
required .TableName tableName = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
required .TableName table_name = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required .TableName table_name = 1;
- getTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .TableName table_name = 1;
- getTableNameBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- getTableNameCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- getTableNameCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
repeated .TableName tableName = 1;
- getTableNameCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponseOrBuilder
-
repeated .TableName tableName = 1;
- getTableNameList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- getTableNameList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
repeated .TableName tableName = 1;
- getTableNameList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponseOrBuilder
-
repeated .TableName tableName = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
optional .TableName table_name = 2;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequestOrBuilder
-
optional .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
optional .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
-
optional .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
optional .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
optional .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
optional .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateDataOrBuilder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateDataOrBuilder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
-
required .TableName table_name = 2;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableName table_name = 3;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
optional .TableName table_name = 3;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
optional .TableName table_name = 3;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequestOrBuilder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequestOrBuilder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequestOrBuilder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequestOrBuilder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequestOrBuilder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequestOrBuilder
-
required .TableName table_name = 1;
- getTableNameOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- getTableNameOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
repeated .TableName tableName = 1;
- getTableNameOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponseOrBuilder
-
repeated .TableName tableName = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequestOrBuilder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequestOrBuilder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequestOrBuilder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .TableName table_name = 4;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional .TableName table_name = 4;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional .TableName table_name = 4;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
required .TableName tableName = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
required .TableName tableName = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequestOrBuilder
-
required .TableName tableName = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequestOrBuilder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
-
required .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .TableName table_name = 1;
- getTableNameOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional .TableName table_name = 1;
- getTableNameOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional .TableName table_name = 1;
- getTableNameOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- getTableNameOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
repeated .TableName tableName = 1;
- getTableNameOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponseOrBuilder
-
repeated .TableName tableName = 1;
- getTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- getTableNameOrRegionName() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- getTableNames() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableNames(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableNames(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableNames() - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- getTableNames(RpcController, MasterProtos.GetTableNamesRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Get list of userspace table names
- getTableNames(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- getTableNames(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
repeated .TableName table_names = 1;
- getTableNames(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
repeated .TableName table_names = 1;
- getTableNames(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- getTableNames(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
repeated .TableName table_names = 1;
- getTableNames(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponseOrBuilder
-
repeated .TableName table_names = 1;
- getTableNames(RpcController, MasterProtos.GetTableNamesRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- getTableNames(RpcController, MasterProtos.GetTableNamesRequest, RpcCallback<MasterProtos.GetTableNamesResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc GetTableNames(.GetTableNamesRequest) returns (.GetTableNamesResponse);
- getTableNames(RpcController, MasterProtos.GetTableNamesRequest, RpcCallback<MasterProtos.GetTableNamesResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc GetTableNames(.GetTableNamesRequest) returns (.GetTableNamesResponse);
- getTableNames(RpcController, MasterProtos.GetTableNamesRequest, RpcCallback<MasterProtos.GetTableNamesResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- getTableNames(AsyncMethodCallback<Hbase.AsyncClient.getTableNames_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getTableNames(AsyncMethodCallback<Hbase.AsyncClient.getTableNames_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getTableNames() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getTableNames() - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
List all the userspace tables.
- getTableNames() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getTableNamesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- getTableNamesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- getTableNamesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- getTableNamesBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- getTableNamesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- getTableNamesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
repeated .TableName table_names = 1;
- getTableNamesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
repeated .TableName table_names = 1;
- getTableNamesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- getTableNamesCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
repeated .TableName table_names = 1;
- getTableNamesCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponseOrBuilder
-
repeated .TableName table_names = 1;
- getTableNamesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- getTableNamesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
repeated .TableName table_names = 1;
- getTableNamesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
repeated .TableName table_names = 1;
- getTableNamesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- getTableNamesList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
repeated .TableName table_names = 1;
- getTableNamesList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponseOrBuilder
-
repeated .TableName table_names = 1;
- getTableNamesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- getTableNamesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
repeated .TableName table_names = 1;
- getTableNamesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
repeated .TableName table_names = 1;
- getTableNamesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- getTableNamesOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
repeated .TableName table_names = 1;
- getTableNamesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponseOrBuilder
-
repeated .TableName table_names = 1;
- getTableNamesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- getTableNamesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
repeated .TableName table_names = 1;
- getTableNamesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
repeated .TableName table_names = 1;
- getTableNamesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- getTableNamesOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
repeated .TableName table_names = 1;
- getTableNamesOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponseOrBuilder
-
repeated .TableName table_names = 1;
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- getTableOperationType() - Method in interface org.apache.hadoop.hbase.master.procedure.TableProcedureInterface
-
Given an operation type we can take decisions about what to do with pending operations.
- getTableOperationType() - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- getTableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .TableSchema table = 3;
- getTableOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
optional .TableSchema table = 3;
- getTableOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplitOrBuilder
-
optional .TableSchema table = 3;
- getTablePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .TablePermission table_permission = 4;
- getTablePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
optional .TablePermission table_permission = 4;
- getTablePermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
-
optional .TablePermission table_permission = 4;
- getTablePermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .TablePermission table_permission = 4;
- getTablePermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .TablePermission table_permission = 4;
- getTablePermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
optional .TablePermission table_permission = 4;
- getTablePermissionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
-
optional .TablePermission table_permission = 4;
- getTableQuota(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getTableRegions(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Get the regions of a given table.
- getTableRegions(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
get the regions of a given table.
- getTableRegions(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- getTableRegions(ZooKeeperWatcher, Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Gets all of the regions of the specified table.
- getTableRegions(ZooKeeperWatcher, Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Gets all of the regions of the specified table.
- getTableRegions(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getTableRegions_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getTableRegions(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getTableRegions_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getTableRegions(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getTableRegions(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
List the regions associated with a table.
- getTableRegions(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- getTableRegionsAndLocations(ZooKeeperWatcher, Connection, TableName) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getTableRegionsAndLocations(ZooKeeperWatcher, Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- getTableResource(String) - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- getTableRowKey(TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getTableRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getTables() - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .TableSchema table_schema = 2;
- getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
required .TableSchema table_schema = 2;
- getTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
-
required .TableSchema table_schema = 2;
- getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableSchema table_schema = 4;
- getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
optional .TableSchema table_schema = 4;
- getTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
optional .TableSchema table_schema = 4;
- getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
required .TableSchema table_schema = 1;
- getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
required .TableSchema table_schema = 1;
- getTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequestOrBuilder
-
required .TableSchema table_schema = 1;
- getTableSchema(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- getTableSchema(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
repeated .TableSchema table_schema = 1;
- getTableSchema(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponseOrBuilder
-
repeated .TableSchema table_schema = 1;
- getTableSchema(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- getTableSchema(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
repeated .TableSchema tableSchema = 1;
- getTableSchema(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponseOrBuilder
-
repeated .TableSchema tableSchema = 1;
- getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableSchema table_schema = 2;
- getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
required .TableSchema table_schema = 2;
- getTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequestOrBuilder
-
required .TableSchema table_schema = 2;
- getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
required .TableSchema table_schema = 1;
- getTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
required .TableSchema table_schema = 1;
- getTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifestOrBuilder
-
required .TableSchema table_schema = 1;
- getTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .TableSchema table_schema = 2;
- getTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableSchema table_schema = 4;
- getTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
required .TableSchema table_schema = 1;
- getTableSchemaBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- getTableSchemaBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableSchema table_schema = 2;
- getTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
required .TableSchema table_schema = 1;
- getTableSchemaBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- getTableSchemaBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- getTableSchemaCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
repeated .TableSchema table_schema = 1;
- getTableSchemaCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponseOrBuilder
-
repeated .TableSchema table_schema = 1;
- getTableSchemaCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponseOrBuilder
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- getTableSchemaList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
repeated .TableSchema table_schema = 1;
- getTableSchemaList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponseOrBuilder
-
repeated .TableSchema table_schema = 1;
- getTableSchemaList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponseOrBuilder
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .TableSchema table_schema = 2;
- getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
required .TableSchema table_schema = 2;
- getTableSchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
-
required .TableSchema table_schema = 2;
- getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableSchema table_schema = 4;
- getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
optional .TableSchema table_schema = 4;
- getTableSchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
optional .TableSchema table_schema = 4;
- getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
required .TableSchema table_schema = 1;
- getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
required .TableSchema table_schema = 1;
- getTableSchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequestOrBuilder
-
required .TableSchema table_schema = 1;
- getTableSchemaOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- getTableSchemaOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
repeated .TableSchema table_schema = 1;
- getTableSchemaOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponseOrBuilder
-
repeated .TableSchema table_schema = 1;
- getTableSchemaOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponseOrBuilder
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableSchema table_schema = 2;
- getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
required .TableSchema table_schema = 2;
- getTableSchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequestOrBuilder
-
required .TableSchema table_schema = 2;
- getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
required .TableSchema table_schema = 1;
- getTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
required .TableSchema table_schema = 1;
- getTableSchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifestOrBuilder
-
required .TableSchema table_schema = 1;
- getTableSchemaOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- getTableSchemaOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
repeated .TableSchema table_schema = 1;
- getTableSchemaOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponseOrBuilder
-
repeated .TableSchema table_schema = 1;
- getTableSchemaOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
repeated .TableSchema tableSchema = 1;
- getTableSchemaOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponseOrBuilder
-
repeated .TableSchema tableSchema = 1;
- getTableSet() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get the table set
- getTablesInStates(ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
- getTablesInStates(ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Gets a list of all the tables set as disabling in zookeeper.
- getTablesOnMaster(Configuration) - Static method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- getTableStateManager() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
Returns implementation of TableStateManager.
- getTableStateManager() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
- getTableStateManager() - Method in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- getTableStateManager() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- getTableStoreFilePathMap(Map<String, Path>, FileSystem, Path, TableName) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir/tablename and creates a reverse lookup map for
table StoreFile names to the full Path.
- getTableStoreFilePathMap(Map<String, Path>, FileSystem, Path, TableName, HBaseFsck.ErrorReporter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir/tablename and creates a reverse lookup map for
table StoreFile names to the full Path.
- getTableStoreFilePathMap(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and creates a reverse lookup map for
table StoreFile names to the full Path.
- getTableStoreFilePathMap(FileSystem, Path, HBaseFsck.ErrorReporter) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Runs through the HBase rootdir and creates a reverse lookup map for
table StoreFile names to the full Path.
- getTableToRegionMap() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
Get regions for tables
- getTag(byte[], int, int, byte) - Static method in class org.apache.hadoop.hbase.Tag
-
Retrieve the first tag from the tags byte array matching the passed in tag type
- getTag(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Get a tag by name
- getTagArray(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Returns tag value in a new byte array.
- getTagBufferLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- getTagCompressionContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
-
- getTagCompressionContext() - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- getTagLength() - Method in class org.apache.hadoop.hbase.Tag
-
- getTagOffset(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getTagOffset() - Method in class org.apache.hadoop.hbase.Tag
-
- getTags() - Method in class org.apache.hadoop.hbase.KeyValue
-
Returns any tags embedded in the KeyValue.
- getTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes tags = 7;
- getTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional bytes tags = 7;
- getTags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional bytes tags = 7;
- getTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional bytes tags = 7;
- getTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
optional bytes tags = 7;
- getTags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
optional bytes tags = 7;
- getTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional bytes tags = 5;
- getTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
optional bytes tags = 5;
- getTags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
-
optional bytes tags = 5;
- getTags() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- getTagsArray() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTagsArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getTagsLength() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
This returns the total length of the tag bytes
- getTagsLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.NoTagsKeyValue
-
- getTagsLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getTagsOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
This returns the offset where the tag actually starts.
- getTagsOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTagsOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getTagsOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getTagSorter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getTagWriter() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getTailKbParam(HttpServletRequest) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- getTailPtr() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Get the tail of the linked list (most recently used).
- getTaskMonitor() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getTaskMonitor__IsNotDefault() - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- getTaskNode() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- getTaskReadySeq() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
Used by unit tests to check how many tasks were processed
- getTaskReadySeq() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- getTaskReadySeq() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
Returns the number of tasks processed by coordination.
- getTasks() - Method in class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
- getTasks() - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
Produces a list containing copies of the current state of all non-expired
MonitoredTasks handled by this TaskMonitor.
- getTempDir() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- getThird() - Method in class org.apache.hadoop.hbase.util.Triple
-
- getThread() - Method in class org.apache.hadoop.hbase.util.HasThread
-
- getThreadCount() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- getThreadCount() - Method in class org.apache.hadoop.hbase.master.BulkReOpen
-
Configuration knobs "hbase.bulk.reopen.threadpool.size" number of regions
that can be reopened concurrently.
- getThreadId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional int64 thread_id = 3;
- getThreadId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional int64 thread_id = 3;
- getThreadId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional int64 thread_id = 3;
- getThreadInfo(Thread) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
- getThreadNamePrefix() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- getThreadNamePrefix() - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
-
- getThreadWakeFrequency() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Interval at which threads should run
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.AlreadyExists._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.BatchMutation._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.append_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.get_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.IllegalArgument._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.IOError._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.Mutation._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TAppend._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TCell._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TColumn._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TIncrement._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TRegionInfo._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TRowResult._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift.generated.TScan._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TAppend._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TAuthorization._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TCellVisibility._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumn._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TColumnValue._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TDelete._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TGet._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIncrement._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TIOError._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TMutation._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TPut._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TResult._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TRowMutations._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TScan._Fields
-
- getThriftFieldId() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TTimeRange._Fields
-
- getThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .ThrottleRequest throttle = 7;
- getThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional .ThrottleRequest throttle = 7;
- getThrottle() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional .ThrottleRequest throttle = 7;
- getThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
optional .Throttle throttle = 2;
- getThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
optional .Throttle throttle = 2;
- getThrottle() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotasOrBuilder
-
optional .Throttle throttle = 2;
- getThrottleBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .ThrottleRequest throttle = 7;
- getThrottleBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
optional .Throttle throttle = 2;
- getThrottleOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .ThrottleRequest throttle = 7;
- getThrottleOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional .ThrottleRequest throttle = 7;
- getThrottleOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional .ThrottleRequest throttle = 7;
- getThrottleOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
optional .Throttle throttle = 2;
- getThrottleOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
optional .Throttle throttle = 2;
- getThrottleOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotasOrBuilder
-
optional .Throttle throttle = 2;
- getThrottlePoint() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- getThroughputControllerClass(Configuration) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputControllerFactory
-
- getTicket() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
-
- getTimedQuota() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
optional .TimedQuota timed_quota = 2;
- getTimedQuota() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
optional .TimedQuota timed_quota = 2;
- getTimedQuota() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequestOrBuilder
-
optional .TimedQuota timed_quota = 2;
- getTimedQuotaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
optional .TimedQuota timed_quota = 2;
- getTimedQuotaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
optional .TimedQuota timed_quota = 2;
- getTimedQuotaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
optional .TimedQuota timed_quota = 2;
- getTimedQuotaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequestOrBuilder
-
optional .TimedQuota timed_quota = 2;
- getTimeOfDeath(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Get the time when a server died
- getTimeout() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getTimeout(T) - Method in interface org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue.TimeoutRetriever
-
- getTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint32 timeout = 9;
- getTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional uint32 timeout = 9;
- getTimeout() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional uint32 timeout = 9;
- getTimeoutOnRIT() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- getTimeoutOnRIT() - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
-
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for retrieving the get's TimeRange
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Increment
-
Gets the TimeRange used for this increment.
- getTimeRange() - Method in class org.apache.hadoop.hbase.client.Scan
-
- getTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .TimeRange time_range = 5;
- getTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional .TimeRange time_range = 5;
- getTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional .TimeRange time_range = 5;
- getTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .TimeRange time_range = 7;
- getTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional .TimeRange time_range = 7;
- getTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional .TimeRange time_range = 7;
- getTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .TimeRange time_range = 6;
- getTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional .TimeRange time_range = 6;
- getTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional .TimeRange time_range = 6;
- getTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getTimeRange() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- getTimeRangeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .TimeRange time_range = 5;
- getTimeRangeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .TimeRange time_range = 7;
- getTimeRangeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .TimeRange time_range = 6;
- getTimeRangeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .TimeRange time_range = 5;
- getTimeRangeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional .TimeRange time_range = 5;
- getTimeRangeOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional .TimeRange time_range = 5;
- getTimeRangeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .TimeRange time_range = 7;
- getTimeRangeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional .TimeRange time_range = 7;
- getTimeRangeOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional .TimeRange time_range = 7;
- getTimeRangeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .TimeRange time_range = 6;
- getTimeRangeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional .TimeRange time_range = 6;
- getTimeRangeOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional .TimeRange time_range = 6;
- getTimeRangeTracker() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSnapshot
-
- getTimeRemaining() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- getTimestamp() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.client.ClientScanner
-
- getTimeStamp() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for retrieving the timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
optional uint64 timestamp = 3;
- getTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
optional uint64 timestamp = 3;
- getTimestamp() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
-
optional uint64 timestamp = 3;
- getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional uint64 timestamp = 4;
- getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional uint64 timestamp = 4;
- getTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional uint64 timestamp = 4;
- getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional uint64 timestamp = 4;
- getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
optional uint64 timestamp = 4;
- getTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
optional uint64 timestamp = 4;
- getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional uint64 timestamp = 4;
- getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional uint64 timestamp = 3;
- getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
optional uint64 timestamp = 3;
- getTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
-
optional uint64 timestamp = 3;
- getTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional uint64 timestamp = 4;
- getTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional uint64 timestamp = 4;
- getTimeStamp() - Method in interface org.apache.hadoop.hbase.regionserver.RegionMergeTransaction.JournalEntry
-
- getTimeStamp() - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl.JournalEntryImpl
-
- getTimeStamp() - Method in interface org.apache.hadoop.hbase.regionserver.SplitTransaction.JournalEntry
-
- getTimeStamp() - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional int64 timestamp = 3;
- getTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
optional int64 timestamp = 3;
- getTimestamp() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
optional int64 timestamp = 3;
- getTimestamp() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
timestamp
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- getTimestamp() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- getTimestampDeltaWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
get/set
- getTimestampEncoder() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getTimestampIndex(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getTimestampIndexWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getTimestampKeyColumnIndex() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- getTimestampOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getTimestampOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTimeStampOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Get the TimeStampOfLastAppliedOp.
- getTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint64 timeStampOfLastShippedOp = 4;
- getTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
required uint64 timeStampOfLastShippedOp = 4;
- getTimeStampOfLastShippedOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
-
required uint64 timeStampOfLastShippedOp = 4;
- getTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Get the timeStampsOfLastShippedOp
- getTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
-
- getTimestamps() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getTimestamps() - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
-
- getTimestamps(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
repeated int64 timestamps = 1 [packed = true];
- getTimestamps(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
repeated int64 timestamps = 1 [packed = true];
- getTimestamps(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilterOrBuilder
-
repeated int64 timestamps = 1 [packed = true];
- getTimestampsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
repeated int64 timestamps = 1 [packed = true];
- getTimestampsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
repeated int64 timestamps = 1 [packed = true];
- getTimestampsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilterOrBuilder
-
repeated int64 timestamps = 1 [packed = true];
- getTimestampsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
repeated int64 timestamps = 1 [packed = true];
- getTimestampsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
repeated int64 timestamps = 1 [packed = true];
- getTimestampsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilterOrBuilder
-
repeated int64 timestamps = 1 [packed = true];
- getTimeStampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
required uint64 timeStampsOfLastAppliedOp = 2;
- getTimeStampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
required uint64 timeStampsOfLastAppliedOp = 2;
- getTimeStampsOfLastAppliedOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSinkOrBuilder
-
required uint64 timeStampsOfLastAppliedOp = 2;
- getTimeStampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
-
- getTimestampString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- getTimeToLive() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getTimeToLive() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- getTimeToPurgeDeletes() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getTimeUnit(T) - Method in interface org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue.TimeoutRetriever
-
- getTimeUnit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
required .TimeUnit time_unit = 1;
- getTimeUnit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
required .TimeUnit time_unit = 1;
- getTimeUnit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuotaOrBuilder
-
required .TimeUnit time_unit = 1;
- getTimeUnit() - Method in class org.apache.hadoop.hbase.ScheduledChore
-
- getTimeUnit() - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- getTimeUnitInMillis() - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- getTo() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
optional uint64 to = 2;
- getTo() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
optional uint64 to = 2;
- getTo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRangeOrBuilder
-
optional uint64 to = 2;
- getToken() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getToken() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
optional .Token token = 1;
- getToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
optional .Token token = 1;
- getToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponseOrBuilder
-
optional .Token token = 1;
- getToken(String, String) - Method in class org.apache.hadoop.hbase.security.User
-
Returns the Token of the specified kind associated with this user,
or null if the Token is not present.
- getTokenArrayOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getTokenBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
optional .Token token = 1;
- getTokenKind() - Method in class org.apache.hadoop.hbase.security.SecurityInfo
-
- getTokenLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.column.ColumnNodeReader
-
get/set
- getTokenLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getTokenLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- getTokenOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
autogenerated get/set
- getTokenOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
optional .Token token = 1;
- getTokenOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
optional .Token token = 1;
- getTokenOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponseOrBuilder
-
optional .Token token = 1;
- getTokens() - Method in class org.apache.hadoop.hbase.security.User
-
Returns all the tokens stored in the user's credentials.
- getTopHosts() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
return the sorted list of hosts in terms of their weights
- getTopHostsWithWeights() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
return the sorted list of hosts in terms of their weights
- getTotalBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getTotalBufferedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getTotalBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getTotalBytesRead() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
Getter for the number of bytes read from this stream, since creation.
- getTotalCompactedSize() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 total_compacting_KVs = 10;
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint64 total_compacting_KVs = 10;
- getTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint64 total_compacting_KVs = 10;
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getTotalCompactingKvs() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionProgress
-
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 totalCompactingKVs = 12;
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int64 totalCompactingKVs = 12;
- getTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int64 totalCompactingKVs = 12;
- getTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalCompressedBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
- getTotalFailedCounter() - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- getTotalFileSize(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- getTotalIncrements() - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- getTotalIncrements() - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- getTotalLengthOfArrays(Iterable<byte[]>) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
-
- getTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 total_number_of_requests = 2;
- getTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint64 total_number_of_requests = 2;
- getTotalNumberOfRequests() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint64 total_number_of_requests = 2;
- getTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalQueueSize() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapper
-
- getTotalQueueSize() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerWrapperImpl
-
- getTotalRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
optional uint32 total_regions = 2;
- getTotalRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
optional uint32 total_regions = 2;
- getTotalRegions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponseOrBuilder
-
optional uint32 total_regions = 2;
- getTotalRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the total number of requests per second.
- getTotalRequestsCount(ClusterStatusProtos.RegionLoad) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
- getTotalSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getTotalSizeOfCells(Result) - Static method in class org.apache.hadoop.hbase.client.Result
-
Get total size of raw cells
- getTotalSizeWhenWrittenDelimited(Message...) - Static method in class org.apache.hadoop.hbase.ipc.IPCUtil
-
- getTotalSleepTime() - Method in class org.apache.hadoop.hbase.io.hadoopbackport.ThrottledInputStream
-
Getter the total time spent in sleep.
- getTotalStaticBloomSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getTotalStaticBloomSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size (in bytes) of the static bloom filters.
- getTotalStaticBloomSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the total byte size of all Bloom filter bit arrays.
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 total_static_bloom_size_KB = 14;
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 total_static_bloom_size_KB = 14;
- getTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 total_static_bloom_size_KB = 14;
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 totalStaticBloomSizeKB = 11;
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 totalStaticBloomSizeKB = 11;
- getTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 totalStaticBloomSizeKB = 11;
- getTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalStaticIndexSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- getTotalStaticIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size (in bytes) of of the static indexes including the roots.
- getTotalStaticIndexSize() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Returns the total size of all index blocks in the data block indexes, including the root level,
intermediate levels, and the leaf level for multi-level indexes, or just the root level for
single-level indexes.
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 total_static_index_size_KB = 13;
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 total_static_index_size_KB = 13;
- getTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 total_static_index_size_KB = 13;
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 totalStaticIndexSizeKB = 10;
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 totalStaticIndexSizeKB = 10;
- getTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 totalStaticIndexSizeKB = 10;
- getTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getTotalTableFragmentation(HMaster) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Returns the total overall fragmentation percentage.
- getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 total_uncompressed_bytes = 4;
- getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 total_uncompressed_bytes = 4;
- getTotalUncompressedBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 total_uncompressed_bytes = 4;
- getTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- getTotalUncompressedSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
The total uncompressed size of the root index block, intermediate-level
index blocks, and leaf-level index blocks.
- getTrace(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- getTrace(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
repeated .StackTraceElementMessage trace = 4;
- getTrace(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
repeated .StackTraceElementMessage trace = 4;
- getTraceBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- getTraceBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- getTraceCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- getTraceCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
repeated .StackTraceElementMessage trace = 4;
- getTraceCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
repeated .StackTraceElementMessage trace = 4;
- getTraceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
optional int64 trace_id = 1;
- getTraceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
optional int64 trace_id = 1;
- getTraceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfoOrBuilder
-
optional int64 trace_id = 1;
- getTraceInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .RPCTInfo trace_info = 2;
- getTraceInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional .RPCTInfo trace_info = 2;
- getTraceInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional .RPCTInfo trace_info = 2;
- getTraceInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .RPCTInfo trace_info = 2;
- getTraceInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .RPCTInfo trace_info = 2;
- getTraceInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional .RPCTInfo trace_info = 2;
- getTraceInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional .RPCTInfo trace_info = 2;
- getTraceList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- getTraceList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
repeated .StackTraceElementMessage trace = 4;
- getTraceList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
repeated .StackTraceElementMessage trace = 4;
- getTraceOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- getTraceOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
repeated .StackTraceElementMessage trace = 4;
- getTraceOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
repeated .StackTraceElementMessage trace = 4;
- getTraceOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- getTraceOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
repeated .StackTraceElementMessage trace = 4;
- getTraceOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
repeated .StackTraceElementMessage trace = 4;
- getTrackerPos() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
required uint64 tracker_pos = 2;
- getTrackerPos() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
required uint64 tracker_pos = 2;
- getTrackerPos() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailerOrBuilder
-
required uint64 tracker_pos = 2;
- getTrailer() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- getTrailer() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- getTrailerSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getTransition(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- getTransition(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
repeated .RegionStateTransition transition = 2;
- getTransition(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequestOrBuilder
-
repeated .RegionStateTransition transition = 2;
- getTransitionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- getTransitionBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- getTransitionCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
required .RegionStateTransition.TransitionCode transition_code = 1;
- getTransitionCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
required .RegionStateTransition.TransitionCode transition_code = 1;
- getTransitionCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransitionOrBuilder
-
required .RegionStateTransition.TransitionCode transition_code = 1;
- getTransitionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- getTransitionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
repeated .RegionStateTransition transition = 2;
- getTransitionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequestOrBuilder
-
repeated .RegionStateTransition transition = 2;
- getTransitionInZK() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional bool transition_in_ZK = 3 [default = true];
- getTransitionInZK() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
optional bool transition_in_ZK = 3 [default = true];
- getTransitionInZK() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
-
optional bool transition_in_ZK = 3 [default = true];
- getTransitionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- getTransitionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
repeated .RegionStateTransition transition = 2;
- getTransitionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequestOrBuilder
-
repeated .RegionStateTransition transition = 2;
- getTransitionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- getTransitionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
repeated .RegionStateTransition transition = 2;
- getTransitionOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequestOrBuilder
-
repeated .RegionStateTransition transition = 2;
- getTransitionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- getTransitionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
repeated .RegionStateTransition transition = 2;
- getTransitionOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequestOrBuilder
-
repeated .RegionStateTransition transition = 2;
- getTreeBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
getters
- getTreeDepth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
- getTs() - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
- getTTL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Return the TTL requested for the result of the mutation, in milliseconds.
- getTtl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional uint32 ttl = 4;
- getTtl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
optional uint32 ttl = 4;
- getTtl() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
optional uint32 ttl = 4;
- getTtl() - Method in class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- getTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional int32 ttl = 3;
- getTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
optional int32 ttl = 3;
- getTtl() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
optional int32 ttl = 3;
- getType(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getType() - Method in class org.apache.hadoop.hbase.KeyValue
-
Deprecated.
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional .Permission.Type type = 1;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
optional .Permission.Type type = 1;
- getType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequestOrBuilder
-
optional .Permission.Type type = 1;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
required .Permission.Type type = 1;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
required .Permission.Type type = 1;
- getType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
-
required .Permission.Type type = 1;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
required .RegionSpecifier.RegionSpecifierType type = 1;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
required .RegionSpecifier.RegionSpecifierType type = 1;
- getType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifierOrBuilder
-
required .RegionSpecifier.RegionSpecifierType type = 1;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional .SnapshotDescription.Type type = 4 [default = FLUSH];
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
optional .SnapshotDescription.Type type = 4 [default = FLUSH];
- getType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
optional .SnapshotDescription.Type type = 4 [default = FLUSH];
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
required .ProcedureWALEntry.Type type = 1;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
required .ProcedureWALEntry.Type type = 1;
- getType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntryOrBuilder
-
required .ProcedureWALEntry.Type type = 1;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint32 type = 2;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
required uint32 type = 2;
- getType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeaderOrBuilder
-
required uint32 type = 2;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
optional .ThrottleType type = 1;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
optional .ThrottleType type = 1;
- getType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequestOrBuilder
-
optional .ThrottleType type = 1;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
required .SnapshotFileInfo.Type type = 1;
- getType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
required .SnapshotFileInfo.Type type = 1;
- getType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
-
required .SnapshotFileInfo.Type type = 1;
- getType() - Method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
-
- getType() - Method in class org.apache.hadoop.hbase.Tag
-
- getTypeByte() - Method in interface org.apache.hadoop.hbase.Cell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getTypeByte() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getTypeBytes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getTypeFilters() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
- getTypeString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- getUGI() - Method in class org.apache.hadoop.hbase.security.User
-
- getUnblockedFlushCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- getUncaughtExceptionHandler() - Method in class org.apache.hadoop.hbase.master.BulkAssigner
-
- getUncaughtExceptionHandler() - Method in class org.apache.hadoop.hbase.master.GeneralBulkAssigner
-
- getUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- getUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 uncompressed_data_index_size = 3;
- getUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 uncompressed_data_index_size = 3;
- getUncompressedDataIndexSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 uncompressed_data_index_size = 3;
- getUncompressedSizeWithoutHeader() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- getUniqueBlocksTotalWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
- getUniqueFile(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- getUnit(String) - Static method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- getUnknownFields() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- getUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
optional .TableSchema unmodified_table_schema = 2;
- getUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
optional .TableSchema unmodified_table_schema = 2;
- getUnmodifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
-
optional .TableSchema unmodified_table_schema = 2;
- getUnmodifiedTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
optional .TableSchema unmodified_table_schema = 2;
- getUnmodifiedTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
-
optional .TableSchema unmodified_table_schema = 4;
- getUnmodifiedTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
optional .TableSchema unmodified_table_schema = 2;
- getUnmodifiedTableSchemaOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
optional .TableSchema unmodified_table_schema = 2;
- getUnmodifiedTableSchemaOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
-
optional .TableSchema unmodified_table_schema = 2;
- getUnneededFiles(long, List<StoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
- getUnneededFiles(long, List<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- getUnreferencedFiles(Iterable<FileStatus>) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
Check to see if any of the passed file names is contained in any of the snapshots.
- getUpdated(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 updated = 2;
- getUpdated(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
repeated uint64 updated = 2;
- getUpdated(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNodeOrBuilder
-
repeated uint64 updated = 2;
- getUpdatedCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 updated = 2;
- getUpdatedCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
repeated uint64 updated = 2;
- getUpdatedCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNodeOrBuilder
-
repeated uint64 updated = 2;
- getUpdatedList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 updated = 2;
- getUpdatedList() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
repeated uint64 updated = 2;
- getUpdatedList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNodeOrBuilder
-
repeated uint64 updated = 2;
- getUpdatedMaxProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- getUpdatedMinProcId() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- getUpdateInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfo(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfo(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequestOrBuilder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequestOrBuilder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequestOrBuilder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequestOrBuilder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdateInfoOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequestOrBuilder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- getUpdatesBlockedTime() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the amount of time that updates were blocked.
- getUrl() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string url = 2;
- getUrl() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string url = 2;
- getUrl() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string url = 2;
- getUrl() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the subversion URL for the root hbase directory.
- getUrlBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string url = 2;
- getUrlBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string url = 2;
- getUrlBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string url = 2;
- getUsage() - Method in class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- getUsage() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
-
- getUsage() - Method in class org.apache.hadoop.hbase.util.ServerCommandLine
-
Implementing subclasses should return a usage string to print out.
- getUsedBytes() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- getUsedHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint32 used_heap_MB = 3;
- getUsedHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint32 used_heap_MB = 3;
- getUsedHeapMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint32 used_heap_MB = 3;
- getUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getUsedSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
required bytes user = 1;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
required bytes user = 1;
- getUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionOrBuilder
-
required bytes user = 1;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
required bytes user = 1;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
required bytes user = 1;
- getUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissionsOrBuilder
-
required bytes user = 1;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string user = 4;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string user = 4;
- getUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string user = 4;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
-
required bytes user = 1;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
required bytes user = 1;
- getUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequestOrBuilder
-
required bytes user = 1;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
required bytes user = 1;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
required bytes user = 1;
- getUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponseOrBuilder
-
required bytes user = 1;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
required bytes user = 1;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
required bytes user = 1;
- getUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequestOrBuilder
-
required bytes user = 1;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
required bytes user = 1;
- getUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
required bytes user = 1;
- getUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizationsOrBuilder
-
required bytes user = 1;
- getUser() - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- getUser() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- getUser() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getUser() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
The user that compiled hbase.
- getUserAuths(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuths(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuths(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizationsOrBuilder
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuths(byte[], boolean) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getUserAuths(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
- getUserAuths(byte[], boolean) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Retrieve the visibility labels for the user.
- getUserAuthsAsOrdinals(String) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelsCache
-
Returns the list of ordinals of labels associated with the user
- getUserAuthsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizationsOrBuilder
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsDataToWriteToZooKeeper(Map<String, List<Integer>>) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
Creates the user auth data to be written to zookeeper.
- getUserAuthsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizationsOrBuilder
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizationsOrBuilder
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
repeated .UserAuthorizations userAuths = 1;
- getUserAuthsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizationsOrBuilder
-
repeated .UserAuthorizations userAuths = 1;
- getUserBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string user = 4;
- getUserBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string user = 4;
- getUserBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string user = 4;
- getUserFilter() - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
- getUserFromPrincipal(String) - Static method in class org.apache.hadoop.hbase.security.SecurityUtil
-
Get the user name from a principal
- getUserFromRowKey(byte[]) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getUserGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string user_group = 2;
- getUserGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional string user_group = 2;
- getUserGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional string user_group = 2;
- getUserGroupBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string user_group = 2;
- getUserGroupBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional string user_group = 2;
- getUserGroupBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional string user_group = 2;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .UserInformation user_info = 1;
- getUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional .UserInformation user_info = 1;
- getUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional .UserInformation user_info = 1;
- getUserInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional .UserInformation user_info = 1;
- getUserInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional .UserInformation user_info = 1;
- getUserLimiter(UserGroupInformation, TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the limiter associated to the specified user/table.
- getUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
required bytes username = 2;
- getUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
required bytes username = 2;
- getUsername() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
-
required bytes username = 2;
- getUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
optional string username = 1;
- getUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
optional string username = 1;
- getUsername() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponseOrBuilder
-
optional string username = 1;
- getUserName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string user_name = 1;
- getUserName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional string user_name = 1;
- getUserName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional string user_name = 1;
- getUserName() - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- getUsername() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- getUsernameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
optional string username = 1;
- getUsernameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
optional string username = 1;
- getUsernameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponseOrBuilder
-
optional string username = 1;
- getUserNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string user_name = 1;
- getUserNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional string user_name = 1;
- getUserNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional string user_name = 1;
- getUserPermission(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- getUserPermission(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
repeated .UserPermission user_permission = 1;
- getUserPermission(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponseOrBuilder
-
repeated .UserPermission user_permission = 1;
- getUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
required .UserPermission user_permission = 1;
- getUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
required .UserPermission user_permission = 1;
- getUserPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequestOrBuilder
-
required .UserPermission user_permission = 1;
- getUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
required .UserPermission user_permission = 1;
- getUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
required .UserPermission user_permission = 1;
- getUserPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequestOrBuilder
-
required .UserPermission user_permission = 1;
- getUserPermissionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- getUserPermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
required .UserPermission user_permission = 1;
- getUserPermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
required .UserPermission user_permission = 1;
- getUserPermissionBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- getUserPermissionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- getUserPermissionCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
repeated .UserPermission user_permission = 1;
- getUserPermissionCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponseOrBuilder
-
repeated .UserPermission user_permission = 1;
- getUserPermissionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- getUserPermissionList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
repeated .UserPermission user_permission = 1;
- getUserPermissionList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponseOrBuilder
-
repeated .UserPermission user_permission = 1;
- getUserPermissionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- getUserPermissionOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
repeated .UserPermission user_permission = 1;
- getUserPermissionOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponseOrBuilder
-
repeated .UserPermission user_permission = 1;
- getUserPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
required .UserPermission user_permission = 1;
- getUserPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
required .UserPermission user_permission = 1;
- getUserPermissionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequestOrBuilder
-
required .UserPermission user_permission = 1;
- getUserPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
required .UserPermission user_permission = 1;
- getUserPermissionOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
required .UserPermission user_permission = 1;
- getUserPermissionOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequestOrBuilder
-
required .UserPermission user_permission = 1;
- getUserPermissionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- getUserPermissionOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
repeated .UserPermission user_permission = 1;
- getUserPermissionOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponseOrBuilder
-
repeated .UserPermission user_permission = 1;
- getUserPermissions(RpcController, AccessControlProtos.GetUserPermissionsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface
-
- getUserPermissions(RpcController, AccessControlProtos.GetUserPermissionsRequest, RpcCallback<AccessControlProtos.GetUserPermissionsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
-
rpc GetUserPermissions(.GetUserPermissionsRequest) returns (.GetUserPermissionsResponse);
- getUserPermissions(RpcController, AccessControlProtos.GetUserPermissionsRequest, RpcCallback<AccessControlProtos.GetUserPermissionsResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Interface
-
rpc GetUserPermissions(.GetUserPermissionsRequest) returns (.GetUserPermissionsResponse);
- getUserPermissions(RpcController, AccessControlProtos.GetUserPermissionsRequest, RpcCallback<AccessControlProtos.GetUserPermissionsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Stub
-
- getUserPermissions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissions(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissionsOrBuilder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to get user's global permissions.
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, TableName) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to get user table permissions.
- getUserPermissions(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to get permissions for selected namespace.
- getUserPermissions(Connection, String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
List all the userPermissions matching the given pattern.
- getUserPermissions(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- getUserPermissions(RpcController, AccessControlProtos.GetUserPermissionsRequest, RpcCallback<AccessControlProtos.GetUserPermissionsResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- getUserPermissionsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissionsOrBuilder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissionsOrBuilder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissionsOrBuilder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserPermissionsOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissionsOrBuilder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- getUserProvider() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
- getUserQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getUserQuota(Connection, String, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getUserQuota(Connection, String, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getUserQuotaState(UserGroupInformation) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
Returns the QuotaState associated to the specified user.
- getUserRowKey(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getUserRowKeyRegex(String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- getUserToken() - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
- getUseThisHostnameInstead() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
optional string use_this_hostname_instead = 4;
- getUseThisHostnameInstead() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
optional string use_this_hostname_instead = 4;
- getUseThisHostnameInstead() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
-
optional string use_this_hostname_instead = 4;
- getUseThisHostnameInsteadBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
optional string use_this_hostname_instead = 4;
- getUseThisHostnameInsteadBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
optional string use_this_hostname_instead = 4;
- getUseThisHostnameInsteadBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
-
optional string use_this_hostname_instead = 4;
- getUtf8ByteArrays(List<String>) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- getUUIDForCluster(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
Get the UUID for the provided ZK watcher.
- getValue() - Method in interface org.apache.hadoop.hbase.Cell
-
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- getValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Get the latest version of the specified column.
- getValue() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getValue(byte[], byte[], Cell) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- getValue() - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
-
- getValue() - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
-
- getValue(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getValue(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getValue(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Getter for accessing the metadata associated with the key
- getValue(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Getter for accessing the metadata associated with the key
- getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getValue() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getValue() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Gets a buffer view to the current value.
- getValue() - Method in class org.apache.hadoop.hbase.KeyValue
-
Deprecated.
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes value = 6;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional bytes value = 6;
- getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional bytes value = 6;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional bytes value = 6;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
optional bytes value = 6;
- getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
optional bytes value = 6;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .NameBytesPair value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
required .NameBytesPair value = 2;
- getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
-
required .NameBytesPair value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
optional .NameBytesPair value = 1;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
optional .NameBytesPair value = 1;
- getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResultOrBuilder
-
optional .NameBytesPair value = 1;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional bytes value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
optional bytes value = 2;
- getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
-
optional bytes value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
-
optional bytes value = 1;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
optional bytes value = 1;
- getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparableOrBuilder
-
optional bytes value = 1;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
optional bytes value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
optional bytes value = 2;
- getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPairOrBuilder
-
optional bytes value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
optional int64 value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
optional int64 value = 2;
- getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64PairOrBuilder
-
optional int64 value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
required string value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
required string value = 2;
- getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPairOrBuilder
-
required string value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
required bytes value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
required bytes value = 2;
- getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifierOrBuilder
-
required bytes value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
-
required bool value = 1;
- getValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
required bool value = 1;
- getValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponseOrBuilder
-
required bool value = 1;
- getValue() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Get the value of this entry.
- getValue() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
required string value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
required string value = 2;
- getValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
-
required string value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
required string value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
required string value = 2;
- getValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
-
required string value = 2;
- getValue() - Method in class org.apache.hadoop.hbase.Tag
-
Returns tag value in a new byte array.
- getValue() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
Deprecated.
- getValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
amount to increment by
- getValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
the expected value for the column parameter, if not
provided the check is for the non-existence of the
column in question
- getValue() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- getValue() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- getValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- getValue() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TDeleteType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.hadoop.hbase.thrift2.generated.TDurability
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
the expected value, if not provided the
check is for the non-existence of the
column in question
- getValue() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
the expected value, if not provided the
check is for the non-existence of the
column in question
- getValueArray() - Method in interface org.apache.hadoop.hbase.Cell
-
Contiguous raw bytes that may start at any index in the containing array.
- getValueArray() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getValueArray() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getValueArray() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getValueArray() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getValueAsByteBuffer(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value wrapped in a new ByteBuffer
.
- getValueAsByteBuffer(byte[], int, int, byte[], int, int) - Method in class org.apache.hadoop.hbase.client.Result
-
Returns the value wrapped in a new ByteBuffer
.
- getValueBufferShallowCopy(Cell) - Static method in class org.apache.hadoop.hbase.CellUtil
-
- getValueBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .NameBytesPair value = 2;
- getValueBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
optional .NameBytesPair value = 1;
- getValueByteRange() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getValueBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
required string value = 2;
- getValueBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
required string value = 2;
- getValueBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPairOrBuilder
-
required string value = 2;
- getValueBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
required string value = 2;
- getValueBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
required string value = 2;
- getValueBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
-
required string value = 2;
- getValueBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
required string value = 2;
- getValueBytes() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
required string value = 2;
- getValueBytes() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
-
required string value = 2;
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Type
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.CompactionState
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellType
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Consistency
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Durability
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Operator
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Range
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.RegionSpecifierType
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeUnit
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyState
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableState
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyState
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableState
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableState
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableState
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyState
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableState
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableState
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.State
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureState
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaScope
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaType
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleType
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Type
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.FlushAction
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.EventType
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.ScopeType
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.RecoveryMode
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
-
- getValueDescriptor() - Method in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
-
- getValueLength() - Method in interface org.apache.hadoop.hbase.Cell
-
- getValueLength() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getValueLength(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getValueLength(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
- getValueLength() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getValueLength() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getValueLength() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getValueLengthWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getValueOffset() - Method in interface org.apache.hadoop.hbase.Cell
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- getValueOffset(int, PrefixTreeBlockMeta) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- getValueOffset(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.PrefixTreeEncoder
-
convenience getters
- getValueOffset() - Method in class org.apache.hadoop.hbase.KeyValue
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- getValueOffset() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- getValueOffsetWidth() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getValueOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .NameBytesPair value = 2;
- getValueOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
required .NameBytesPair value = 2;
- getValueOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
-
required .NameBytesPair value = 2;
- getValueOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
optional .NameBytesPair value = 1;
- getValueOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
optional .NameBytesPair value = 1;
- getValueOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResultOrBuilder
-
optional .NameBytesPair value = 1;
- getValues() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- getValues() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- getValues(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValues(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValues(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValues() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- getValuesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValueShallowCopy() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
- getValueShallowCopy() - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Does a shallow copy of the value at the current position.
- getValuesIterator() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- getValuesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesOrBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesOrBuilder(int) - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesOrBuilderList() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesOrBuilderList() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- getValuesSize() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- getValueString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- getValueString() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- getValueString() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Convenience method to get a copy of the value as a string - interpreting
the bytes as UTF8.
- getValueString(KeyValue) - Static method in class org.apache.hadoop.hbase.KeyValueTestUtil
-
- getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getVer_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getVer_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the specified number of versions for the specified table,
row, and column.
- getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Deprecated.
- getVer(ByteBuffer, ByteBuffer, byte[], byte[], int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Note: this public interface is slightly different from public Java APIs in regard to
handling of the qualifier.
- getVersion() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- getVersion() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- getVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
-
- getVersion() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
- getVersion() - Method in interface org.apache.hadoop.hbase.CoprocessorEnvironment
-
- getVersion() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
HRI is no longer a VersionedWritable
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
required string version = 1;
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
required string version = 1;
- getVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContentOrBuilder
-
required string version = 1;
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional int32 version = 5;
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
optional int32 version = 5;
- getVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
optional int32 version = 5;
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint32 version = 1;
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
required uint32 version = 1;
- getVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeaderOrBuilder
-
required uint32 version = 1;
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
required uint32 version = 1;
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
required uint32 version = 1;
- getVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailerOrBuilder
-
required uint32 version = 1;
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string version = 1;
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string version = 1;
- getVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string version = 1;
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
optional int32 version = 1;
- getVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
optional int32 version = 1;
- getVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifestOrBuilder
-
optional int32 version = 1;
- getVersion() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
- getVersion() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- getVersion() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- getVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Verifies current version of file system
- getVersion() - Static method in class org.apache.hadoop.hbase.util.VersionInfo
-
Get the hbase version.
- getVersion() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.AcquiredLock
-
- getVersion(ZooKeeperWatcher, HRegionInfo) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Get the version of the specified znode
- getVersionBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
required string version = 1;
- getVersionBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
required string version = 1;
- getVersionBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContentOrBuilder
-
required string version = 1;
- getVersionBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string version = 1;
- getVersionBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string version = 1;
- getVersionBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string version = 1;
- getVersionedBytes() - Method in class org.apache.hadoop.hbase.ServerName
-
- getVersionInfo() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- getVersionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .VersionInfo version_info = 5;
- getVersionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional .VersionInfo version_info = 5;
- getVersionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional .VersionInfo version_info = 5;
- getVersionInfo() - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
Get a protocol buffer VersionInfo
- getVersionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .VersionInfo version_info = 5;
- getVersionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .VersionInfo version_info = 5;
- getVersionInfoOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional .VersionInfo version_info = 5;
- getVersionInfoOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional .VersionInfo version_info = 5;
- getVersionOfClosingNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional uint32 version_of_closing_node = 2;
- getVersionOfClosingNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
optional uint32 version_of_closing_node = 2;
- getVersionOfClosingNode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
-
optional uint32 version_of_closing_node = 2;
- getVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
-
- getVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
optional uint32 version_of_offline_node = 2;
- getVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
optional uint32 version_of_offline_node = 2;
- getVersionOfOfflineNode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
-
optional uint32 version_of_offline_node = 2;
- getVersionResource() - Method in class org.apache.hadoop.hbase.rest.RootResource
-
- getVersionResource() - Method in class org.apache.hadoop.hbase.rest.VersionResource
-
Dispatch /version/rest to self.
- getVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
optional uint64 versionsDeleted = 2;
- getVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
optional uint64 versionsDeleted = 2;
- getVersionsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
-
optional uint64 versionsDeleted = 2;
- getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getVerTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getVerTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get the specified number of versions for the specified table,
row, and column.
- getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Deprecated.
- getVerTs(ByteBuffer, ByteBuffer, byte[], byte[], long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Note: this internal interface is slightly different from public APIs in regard to handling
of the qualifier.
- getVisibilityExpEvaluator(Authorizations) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- getVisibilityExpEvaluator(Authorizations) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Creates VisibilityExpEvaluator corresponding to given Authorizations.
- getVisibilityExpressionResolver() - Method in class org.apache.hadoop.hbase.mapreduce.CellCreator
-
- getVisibilityLabelService(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- getVisibilityLabelService() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityLabelServiceManager
-
- getVisLabel(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabel(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabel(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequestOrBuilder
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequestOrBuilder
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequestOrBuilder
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelOrBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelOrBuilder(int) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequestOrBuilder
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelOrBuilderList() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
repeated .VisibilityLabel visLabel = 1;
- getVisLabelOrBuilderList() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequestOrBuilder
-
repeated .VisibilityLabel visLabel = 1;
- getVLong(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getVLong() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- getVLong(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Retrieve the long value at index
which is stored as VLong
- getVLong() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Retrieve the next long value, which is stored as VLong, from this range
- getVLongSize(long) - Static method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- getWaitInterval(long, long, long) - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
-
- getWaitInterval(long, long, long) - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
-
- getWaitInterval() - Method in exception org.apache.hadoop.hbase.quotas.ThrottlingException
-
- getWAL() - Method in interface org.apache.hadoop.hbase.coprocessor.WALCoprocessorEnvironment
-
- getWAL() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getWAL(HRegionInfo) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getWAL(HRegionInfo) - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
-
- getWAL(byte[]) - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- getWAL(byte[]) - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
- getWAL(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
- getWALActionsListener() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationSourceService
-
Returns a WALObserver for the service.
- getWALActionsListener() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
- getWALArchivePath(Path, Path) - Static method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- getWALDirectoryName(String) - Static method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
Construct the directory name for all WALs on a given server.
- getWalEdit(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- getWALEntryfilter() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
-
Returns a default set of filters
- getWALEntryfilter() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- getWALEntryfilter() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
-
Returns a WALEntryFilter to use for filtering out WALEntries from the log.
- getWALEntryfilter() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- getWALFile() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination.SplitTaskDetails
-
- getWALFile() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- getWALFileSize() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the size of WAL files of this region server.
- getWalName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string wal_name = 5;
- getWalName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
optional string wal_name = 5;
- getWalName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
-
optional string wal_name = 5;
- getWalNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string wal_name = 5;
- getWalNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
optional string wal_name = 5;
- getWalNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
-
optional string wal_name = 5;
- getWALNames(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil
-
Returns the log file names available in the snapshot.
- getWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a copy of the wals of the first source on this rs
- getWalsByIdRecoveredQueues() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Get a copy of the wals of the recovered sources on this rs
- getWalServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string wal_server = 4;
- getWalServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
optional string wal_server = 4;
- getWalServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
-
optional string wal_server = 4;
- getWalServerBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string wal_server = 4;
- getWalServerBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
optional string wal_server = 4;
- getWalServerBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
-
optional string wal_server = 4;
- getWatcher() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- getWatcher() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperListener
-
- getWebAppContext() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- getWebAppsPath(String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- getWebAppsPath(String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Get the pathname to the webapps files.
- getWebuiPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
optional uint32 webui_port = 2;
- getWebuiPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
optional uint32 webui_port = 2;
- getWebuiPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfoOrBuilder
-
optional uint32 webui_port = 2;
- getWeight(String) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
return the weight for a specific host, that will be the total bytes of all
blocks on the host
- getWeight() - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
- getWidthUsingPlaceholderForOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
-
This method is called before blockMeta.qualifierOffsetWidth is known, so we pass in a
placeholder.
- getWorkingSnapshotDir(Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the general working directory for snapshots - where they are built, where they are
temporarily copied on export, etc.
- getWorkingSnapshotDir(HBaseProtos.SnapshotDescription, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory to build a snapshot, before it is finalized
- getWorkingSnapshotDir(String, Path) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Get the directory to build a snapshot, before it is finalized
- getWritable(byte[], Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Set bytes into the passed Writable by calling its
Writable.readFields(java.io.DataInput)
.
- getWritable(byte[], int, int, Writable) - Static method in class org.apache.hadoop.hbase.util.Writables
-
Set bytes into the passed Writable by calling its
Writable.readFields(java.io.DataInput)
.
- getWritableSize() - Method in interface org.apache.hadoop.hbase.io.WritableWithSize
-
Provide a size hint to the caller.
- getWriteAvailable() - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- getWriteAvailable() - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
- getWriteAvailable() - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
- getWriteAvailable() - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- getWriteBuffer() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- getWriteBuffer() - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
since 0.96. This is an internal buffer that should not be read nor write.
- getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.BufferedMutator
-
Returns the maximum size in bytes of the write buffer for this HTable.
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
Returns the maximum size in bytes of the write buffer for this HTable.
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.BufferedMutatorParams
-
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.ConnectionConfiguration
-
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.HTable
-
Returns the maximum size in bytes of the write buffer for this HTable.
- getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- getWriteBufferSize() - Method in interface org.apache.hadoop.hbase.client.Table
-
- getWriteBufferSize() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- getWriteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
optional bool write_flush_wal_marker = 3;
- getWriteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
optional bool write_flush_wal_marker = 3;
- getWriteFlushWalMarker() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
-
optional bool write_flush_wal_marker = 3;
- getWriteNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_num = 3;
- getWriteNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota write_num = 3;
- getWriteNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota write_num = 3;
- getWriteNumBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_num = 3;
- getWriteNumOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_num = 3;
- getWriteNumOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota write_num = 3;
- getWriteNumOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota write_num = 3;
- getWriter() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- getWriterClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional string writer_cls_name = 4;
- getWriterClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
optional string writer_cls_name = 4;
- getWriterClsName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
-
optional string writer_cls_name = 4;
- getWriterClsNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional string writer_cls_name = 4;
- getWriterClsNameBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
optional string writer_cls_name = 4;
- getWriterClsNameBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
-
optional string writer_cls_name = 4;
- getWriterClsNames() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- getWriterClsNames() - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
-
- getWriteRequestCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper
-
Get the total number of mutations that have been issued against this region.
- getWriteRequestCount() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 write_requests_count = 9;
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint64 write_requests_count = 9;
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint64 write_requests_count = 9;
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.RegionLoad
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the number of write requests to regions hosted on this region server.
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 writeRequestsCount = 8;
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int64 writeRequestsCount = 8;
- getWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int64 writeRequestsCount = 8;
- getWriteRequestsCount() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- getWriterFactory(Configuration, CacheConfig) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns the factory to be used to create
HFile
writers
- getWriterFactoryNoCache(Configuration) - Static method in class org.apache.hadoop.hbase.io.hfile.HFile
-
Returns the factory to be used to create
HFile
writers.
- getWriteSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_size = 4;
- getWriteSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota write_size = 4;
- getWriteSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota write_size = 4;
- getWriteSizeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_size = 4;
- getWriteSizeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_size = 4;
- getWriteSizeOrBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota write_size = 4;
- getWriteSizeOrBuilder() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota write_size = 4;
- getWriteTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required uint64 write_time = 4;
- getWriteTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
required uint64 write_time = 4;
- getWriteTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
required uint64 write_time = 4;
- getWriteTime() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- getWriteToWAL() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- getWroteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
optional bool wrote_flush_wal_marker = 3;
- getWroteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
optional bool wrote_flush_wal_marker = 3;
- getWroteFlushWalMarker() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
-
optional bool wrote_flush_wal_marker = 3;
- getYetToUpdateRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
optional uint32 yet_to_update_regions = 1;
- getYetToUpdateRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
optional uint32 yet_to_update_regions = 1;
- getYetToUpdateRegions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponseOrBuilder
-
optional uint32 yet_to_update_regions = 1;
- getZkController() - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- getZKPermissionWatcher() - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- getZKQuorumServersString(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKConfig
-
Return the ZK Quorum servers string given the specified configuration.
- getZkw() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Get the ZK connection to this peer
- getZNodeForReplica(int) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Get the znode string corresponding to a replicaId
- getZnodeVersion() - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination.ZkRegionMergeDetails
-
- getZnodeVersion() - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination.ZkSplitTransactionDetails
-
- getZooKeeper() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- getZooKeeper() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- getZooKeeper() - Method in interface org.apache.hadoop.hbase.Server
-
Gets the ZooKeeper instance for this server.
- getZooKeeper() - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- getZooKeeperClusterKey(Configuration) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the key to the ZK ensemble for this configuration without
adding a name at the end
- getZooKeeperClusterKey(Configuration, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Get the key to the ZK ensemble for this configuration and append
a name at the end
- getZookeeperQuorum() - Method in interface org.apache.hadoop.hbase.master.MetricsMasterWrapper
-
Get the Zookeeper Quorum Info
- getZookeeperQuorum() - Method in class org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
-
- getZookeeperQuorum() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapper
-
Get the Zookeeper Quorum Info
- getZooKeeperServerNum() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- getZooKeeperWatcher() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
- GLOBAL_PERMISSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
- Global_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Type
-
Global = 1;
- grabQuota(long, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Removes the specified write and read amount from the quota.
- grabQuota(long, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- grant(RpcController, AccessControlProtos.GrantRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface
-
- grant(RpcController, AccessControlProtos.GrantRequest, RpcCallback<AccessControlProtos.GrantResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
-
rpc Grant(.GrantRequest) returns (.GrantResponse);
- grant(RpcController, AccessControlProtos.GrantRequest, RpcCallback<AccessControlProtos.GrantResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Interface
-
rpc Grant(.GrantRequest) returns (.GrantResponse);
- grant(RpcController, AccessControlProtos.GrantRequest, RpcCallback<AccessControlProtos.GrantResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Stub
-
- grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to grant a user global permissions.
- grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, TableName, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to grant a user table permissions.
- grant(RpcController, AccessControlProtos.AccessControlService.BlockingInterface, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A utility used to grant a user namespace permissions.
- grant(Connection, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grants permission on the specified table for the specified user
- grant(Connection, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
Grants permission on the specified namespace for the specified user.
- grant(Connection, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- grant(Configuration, TableName, String, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- grant(Configuration, String, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- grant(Configuration, String, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- grant(RpcController, AccessControlProtos.GrantRequest, RpcCallback<AccessControlProtos.GrantResponse>) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- GREATER_OR_EQUAL_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
-
GREATER_OR_EQUAL = 4;
- GREATER_THAN_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
GREATER_THAN Array
- GREATER_THAN_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- GREATER_THAN_OR_EQUAL_TO_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
GREATER_THAN_OR_EQUAL_TO Array
- GREATER_THAN_OR_EQUAL_TO_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- GREATER_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CompareType
-
GREATER = 5;
- GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
JobConf parameter to specify the columns used to produce the key passed to
collect from the map phase
- GROUP_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
JobConf parameter to specify the columns used to produce the key passed to
collect from the map phase.
- GROUP_PREFIX - Static variable in class org.apache.hadoop.hbase.AuthUtil
-
Prefix character to denote group names
- groupHasAccess(String, TableName, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Checks if the user has access to the full table or at least a family/qualifier
for the specified action.
- GroupingTableMap - Class in org.apache.hadoop.hbase.mapred
-
Extract grouping columns from input record
- GroupingTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
- GroupingTableMapper - Class in org.apache.hadoop.hbase.mapreduce
-
Extract grouping columns from input record.
- GroupingTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
- groupOrSplit(Multimap<ByteBuffer, LoadIncrementalHFiles.LoadQueueItem>, LoadIncrementalHFiles.LoadQueueItem, Table, Pair<byte[][], byte[][]>) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
Attempt to assign the given load queue item into its target region group.
- grow(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- growIfNecessary(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
-
- growIfNecessary(int[], int, int) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
-
- growIfNecessary(long[], int, int) - Static method in class org.apache.hadoop.hbase.util.ArrayUtils
-
- GZIP - Static variable in class org.apache.hadoop.hbase.util.Base64
-
Specify that data should be gzip-compressed.
- GzipFilter - Class in org.apache.hadoop.hbase.rest.filter
-
- GzipFilter() - Constructor for class org.apache.hadoop.hbase.rest.filter.GzipFilter
-
- GZIPRequestStream - Class in org.apache.hadoop.hbase.rest.filter
-
- GZIPRequestStream(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
-
- GZIPRequestWrapper - Class in org.apache.hadoop.hbase.rest.filter
-
- GZIPRequestWrapper(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPRequestWrapper
-
- GZIPResponseStream - Class in org.apache.hadoop.hbase.rest.filter
-
- GZIPResponseStream(HttpServletResponse) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
-
- GZIPResponseWrapper - Class in org.apache.hadoop.hbase.rest.filter
-
- GZIPResponseWrapper(HttpServletResponse) - Constructor for class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- H - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'H'
- HalfStoreFileReader - Class in org.apache.hadoop.hbase.io
-
A facade for a
HFile.Reader
that serves up
either the top or bottom half of a HFile where 'bottom' is the first half
of the file containing the keys that sort lowest and 'top' is the second half
of the file with keys that sort greater than those of the bottom half.
- HalfStoreFileReader(FileSystem, Path, CacheConfig, Reference, Configuration) - Constructor for class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
Creates a half file reader for a normal hfile.
- HalfStoreFileReader(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Reference, Configuration) - Constructor for class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
Creates a half file reader for a hfile referred to by an hfilelink.
- handle(Callback[]) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslDigestCallbackHandler
- handle(Callback[]) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslGssCallbackHandler
- handle(int, Random, Throwable) - Method in interface org.apache.hadoop.hbase.security.SaslClientHandler.SaslExceptionHandler
-
Handle the exception
- handleCoprocessorThrowable(CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
This is used by coprocessor hooks which are declared to throw IOException
(or its subtypes).
- handleCreateHdfsRegions(Path, TableName) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
Create the on-disk structure for the table, and returns the regions info.
- handleCreateHdfsRegions(Path, TableName) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
Create the on-disk regions, using the tableRootDir provided by the CreateTableHandler.
- handleDegenerateRegion(HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling a region that has the same start and end key.
- handleDegenerateRegion(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling a region that has the same start and end key.
- handleDuplicateStartKeys(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling two regions that have the same start key.
- handleDuplicateStartKeys(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling two regions that have the same start key.
- handleException(Throwable) - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
Event exception handler, may be overridden
- handleException(Throwable) - Method in class org.apache.hadoop.hbase.master.handler.MetaServerShutdownHandler
-
- handleException(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.handler.RegionReplicaFlushHandler
-
- handleHoleInRegionChain(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling a region hole between two keys.
- handleHoleInRegionChain(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling a region hole between two keys.
- handleHttpInteraction(RestCsrfPreventionFilter.HttpInteraction) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- handleLockMetadata(String) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Process metadata stored in a ZNode using a callback
- handleLockMetadata(String, InterProcessLock.MetadataHandler) - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Process metadata stored in a ZNode using a callback object passed to
this instance.
- handleMetadata(byte[]) - Method in interface org.apache.hadoop.hbase.InterProcessLock.MetadataHandler
-
Called after lock metadata is successfully read from a distributed
lock service.
- handleOverlapGroup(Collection<HBaseFsck.HbckInfo>) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling an group of regions that overlap.
- handleOverlapGroup(Collection<HBaseFsck.HbckInfo>) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling an group of regions that overlap.
- handleOverlapInRegionChain(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling two reigons that overlap in some arbitrary way.
- handleOverlapInRegionChain(HBaseFsck.HbckInfo, HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling two reigons that overlap in some arbitrary way.
- handler - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
- handlerAdded(ChannelHandlerContext) - Method in class org.apache.hadoop.hbase.security.SaslClientHandler
-
- handleRegionEndKeyNotEmpty(byte[]) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling case where a Table has a last region that does not
have an empty end key.
- handleRegionEndKeyNotEmpty(byte[]) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling case where a Table has a last region that does not
have an empty end key.
- handleRegionStartKeyNotEmpty(HBaseFsck.HbckInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Callback for handling case where a Table has a first region that does not
have an empty start key.
- handleRegionStartKeyNotEmpty(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Callback for handling case where a Table has a first region that does not
have an empty start key.
- handleReportForDutyResponse(RegionServerStatusProtos.RegionServerStartupResponse) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.ModifyTableHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableAddFamilyHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableDeleteFamilyHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableEventHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TableModifyFamilyHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.TruncateTableHandler
-
- handleTableOperation(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.snapshot.RestoreSnapshotHandler
-
The restore table is executed in place.
- has(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
A convenience method to determine if this object's familyMap contains
a value assigned to the given family & qualifier.
- has(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Put
-
A convenience method to determine if this object's familyMap contains
a value assigned to the given family, qualifier and timestamp.
- has(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
A convenience method to determine if this object's familyMap contains
a value assigned to the given family, qualifier and timestamp.
- has(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
A convenience method to determine if this object's familyMap contains
the given value assigned to the given family, qualifier and timestamp.
- has(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Check to see if the Constraint is currently set.
- HAS_COMPRESSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- HAS_TAG_COMPRESSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- hasAccess(User, TableName, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- hasAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
required .FlushDescriptor.FlushAction action = 1;
- hasAction() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
required .FlushDescriptor.FlushAction action = 1;
- hasAction() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
required .FlushDescriptor.FlushAction action = 1;
- hasAdministratorAccess(ServletContext, HttpServletRequest, HttpServletResponse) - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
Does the user sending the HttpServletRequest has the administrator ACLs? If
it isn't the case, response will be modified to send an error to the user.
- hasAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
required uint64 ageOfLastAppliedOp = 1;
- hasAgeOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
required uint64 ageOfLastAppliedOp = 1;
- hasAgeOfLastAppliedOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSinkOrBuilder
-
required uint64 ageOfLastAppliedOp = 1;
- hasAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint64 ageOfLastShippedOp = 2;
- hasAgeOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
required uint64 ageOfLastShippedOp = 2;
- hasAgeOfLastShippedOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
-
required uint64 ageOfLastShippedOp = 2;
- hasAlgorithm() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required string algorithm = 1;
- hasAlgorithm() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
required string algorithm = 1;
- hasAlgorithm() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
-
required string algorithm = 1;
- hasAllowPartialResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool allow_partial_results = 18;
- hasAllowPartialResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bool allow_partial_results = 18;
- hasAllowPartialResults() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bool allow_partial_results = 18;
- hasAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
optional bool assign_seq_num = 3;
- hasAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
optional bool assign_seq_num = 3;
- hasAssignSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
-
optional bool assign_seq_num = 3;
- hasAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
optional bool assign_seq_num = 2;
- hasAssignSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
optional bool assign_seq_num = 2;
- hasAssignSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
optional bool assign_seq_num = 2;
- hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
optional int32 associated_cell_count = 3;
- hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
optional int32 associated_cell_count = 3;
- hasAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
-
optional int32 associated_cell_count = 3;
- hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional int32 associated_cell_count = 8;
- hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional int32 associated_cell_count = 8;
- hasAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional int32 associated_cell_count = 8;
- hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional int32 associated_cell_count = 2;
- hasAssociatedCellCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
optional int32 associated_cell_count = 2;
- hasAssociatedCellCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
optional int32 associated_cell_count = 2;
- hasAtomic() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
optional bool atomic = 2;
- hasAtomic() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
optional bool atomic = 2;
- hasAtomic() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionOrBuilder
-
optional bool atomic = 2;
- hasAttributes() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- hasAuthMethod() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
optional string auth_method = 2;
- hasAuthMethod() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
optional string auth_method = 2;
- hasAuthMethod() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponseOrBuilder
-
optional string auth_method = 2;
- hasAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
optional double averageLoad = 5;
- hasAverageLoad() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
optional double averageLoad = 5;
- hasAverageLoad() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
optional double averageLoad = 5;
- hasBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional bool balancer_on = 9;
- hasBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
optional bool balancer_on = 9;
- hasBalancerOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
optional bool balancer_on = 9;
- hasBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
-
optional bool balancer_on = 1;
- hasBalancerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
optional bool balancer_on = 1;
- hasBalancerOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerStateOrBuilder
-
optional bool balancer_on = 1;
- hasBalancerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
-
required bool balancer_ran = 1;
- hasBalancerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
required bool balancer_ran = 1;
- hasBalancerRan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponseOrBuilder
-
required bool balancer_ran = 1;
- hasBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int32 batch = 4;
- hasBatch() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional int32 batch = 4;
- hasBatch() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional int32 batch = 4;
- hasBatchSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 batch_size = 9;
- hasBatchSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional uint32 batch_size = 9;
- hasBatchSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional uint32 batch_size = 9;
- hasBigdecimalMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
-
required bytes bigdecimal_msg = 1;
- hasBigdecimalMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
required bytes bigdecimal_msg = 1;
- hasBigdecimalMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsgOrBuilder
-
required bytes bigdecimal_msg = 1;
- hasBitwiseOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
required .BitComparator.BitwiseOp bitwise_op = 2;
- hasBitwiseOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
required .BitComparator.BitwiseOp bitwise_op = 2;
- hasBitwiseOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparatorOrBuilder
-
required .BitComparator.BitwiseOp bitwise_op = 2;
- hasBody() - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- hasBulkloadSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required int64 bulkload_seq_num = 4;
- hasBulkloadSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
required int64 bulkload_seq_num = 4;
- hasBulkloadSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
-
required int64 bulkload_seq_num = 4;
- hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
required string bulk_token = 1;
- hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
required string bulk_token = 1;
- hasBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequestOrBuilder
-
required string bulk_token = 1;
- hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
required string bulk_token = 1;
- hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
required string bulk_token = 1;
- hasBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponseOrBuilder
-
required string bulk_token = 1;
- hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required string bulk_token = 4;
- hasBulkToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
required string bulk_token = 4;
- hasBulkToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
required string bulk_token = 4;
- hasBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional bool bypass_globals = 6;
- hasBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional bool bypass_globals = 6;
- hasBypassGlobals() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional bool bypass_globals = 6;
- hasBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
optional bool bypass_globals = 1 [default = false];
- hasBypassGlobals() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
optional bool bypass_globals = 1 [default = false];
- hasBypassGlobals() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotasOrBuilder
-
optional bool bypass_globals = 1 [default = false];
- hasBypassGlobals() - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
- hasCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional bool cache_blocks = 7 [default = true];
- hasCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional bool cache_blocks = 7 [default = true];
- hasCacheBlocks() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional bool cache_blocks = 7 [default = true];
- hasCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool cache_blocks = 8 [default = true];
- hasCacheBlocks() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bool cache_blocks = 8 [default = true];
- hasCacheBlocks() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bool cache_blocks = 8 [default = true];
- hasCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional bool cacheBlocks = 11;
- hasCacheBlocks() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional bool cacheBlocks = 11;
- hasCacheBlocks() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional bool cacheBlocks = 11;
- hasCaching() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 caching = 17;
- hasCaching() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional uint32 caching = 17;
- hasCaching() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional uint32 caching = 17;
- hasCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int32 caching = 9;
- hasCaching() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional int32 caching = 9;
- hasCaching() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional int32 caching = 9;
- hasCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .CoprocessorServiceCall call = 2;
- hasCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
required .CoprocessorServiceCall call = 2;
- hasCall() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
-
required .CoprocessorServiceCall call = 2;
- hasCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional uint32 call_id = 1;
- hasCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional uint32 call_id = 1;
- hasCallId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional uint32 call_id = 1;
- hasCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional uint32 call_id = 1;
- hasCallId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
optional uint32 call_id = 1;
- hasCallId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
-
optional uint32 call_id = 1;
- hasCallTimeout() - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
-
- hasCellBlockCodecClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string cell_block_codec_class = 3;
- hasCellBlockCodecClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional string cell_block_codec_class = 3;
- hasCellBlockCodecClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional string cell_block_codec_class = 3;
- hasCellBlockCompressorClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string cell_block_compressor_class = 4;
- hasCellBlockCompressorClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional string cell_block_compressor_class = 4;
- hasCellBlockCompressorClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional string cell_block_compressor_class = 4;
- hasCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 5;
- hasCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional .CellBlockMeta cell_block_meta = 5;
- hasCellBlockMeta() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional .CellBlockMeta cell_block_meta = 5;
- hasCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 3;
- hasCellBlockMeta() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
optional .CellBlockMeta cell_block_meta = 3;
- hasCellBlockMeta() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
-
optional .CellBlockMeta cell_block_meta = 3;
- hasCellBlockSupport() - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
- hasCellBlockSupport() - Method in class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
- hasCellBlockSupport() - Method in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- hasCellCodecClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional string cell_codec_cls_name = 5;
- hasCellCodecClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
optional string cell_codec_cls_name = 5;
- hasCellCodecClsName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
-
optional string cell_codec_cls_name = 5;
- hasCellTTL() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- hasCellType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional .CellType cell_type = 5;
- hasCellType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional .CellType cell_type = 5;
- hasCellType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional .CellType cell_type = 5;
- hasCellVisibility() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- hasChance() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
-
required float chance = 1;
- hasChance() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
required float chance = 1;
- hasChance() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilterOrBuilder
-
required float chance = 1;
- hasCharset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required string charset = 3;
- hasCharset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
required string charset = 3;
- hasCharset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
-
required string charset = 3;
- hasChildren() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- hasClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional string class_name = 1;
- hasClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
optional string class_name = 1;
- hasClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
optional string class_name = 1;
- hasClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required string class_name = 1;
- hasClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
required string class_name = 1;
- hasClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
required string class_name = 1;
- hasClientAckTime() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- hasClientHandlesHeartbeats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool client_handles_heartbeats = 8;
- hasClientHandlesHeartbeats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional bool client_handles_heartbeats = 8;
- hasClientHandlesHeartbeats() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional bool client_handles_heartbeats = 8;
- hasClientHandlesPartials() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool client_handles_partials = 7;
- hasClientHandlesPartials() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional bool client_handles_partials = 7;
- hasClientHandlesPartials() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional bool client_handles_partials = 7;
- hasClosed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
-
required bool closed = 1;
- hasClosed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
required bool closed = 1;
- hasClosed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponseOrBuilder
-
required bool closed = 1;
- hasCloseScanner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool close_scanner = 5;
- hasCloseScanner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional bool close_scanner = 5;
- hasCloseScanner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional bool close_scanner = 5;
- hasClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional bool closest_row_before = 11 [default = false];
- hasClosestRowBefore() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional bool closest_row_before = 11 [default = false];
- hasClosestRowBefore() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional bool closest_row_before = 11 [default = false];
- hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
required string cluster_id = 1;
- hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
required string cluster_id = 1;
- hasClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterIdOrBuilder
-
required string cluster_id = 1;
- hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ClusterId cluster_id = 5;
- hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
optional .ClusterId cluster_id = 5;
- hasClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
optional .ClusterId cluster_id = 5;
- hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
Deprecated.
- hasClusterId() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
Deprecated.
- hasClusterId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
Deprecated.
- hasClusterkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
required string clusterkey = 1;
- hasClusterkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
required string clusterkey = 1;
- hasClusterkey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
required string clusterkey = 1;
- hasClusterStatus() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
required .ClusterStatus cluster_status = 1;
- hasClusterStatus() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
required .ClusterStatus cluster_status = 1;
- hasClusterStatus() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponseOrBuilder
-
required .ClusterStatus cluster_status = 1;
- hasColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional bytes column = 2;
- hasColumn() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
optional bytes column = 2;
- hasColumn() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
optional bytes column = 2;
- hasColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- hasColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
required .ColumnFamilySchema column_families = 2;
- hasColumnFamilies() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequestOrBuilder
-
required .ColumnFamilySchema column_families = 2;
- hasColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- hasColumnFamilies() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
required .ColumnFamilySchema column_families = 2;
- hasColumnFamilies() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequestOrBuilder
-
required .ColumnFamilySchema column_families = 2;
- hasColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
optional bytes column_family = 2;
- hasColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
optional bytes column_family = 2;
- hasColumnFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
-
optional bytes column_family = 2;
- hasColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bytes column_family = 1;
- hasColumnFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
optional bytes column_family = 1;
- hasColumnFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
optional bytes column_family = 1;
- hasColumnfamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required bytes columnfamily_name = 3;
- hasColumnfamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
required bytes columnfamily_name = 3;
- hasColumnfamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
-
required bytes columnfamily_name = 3;
- hasColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- hasColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
required .ColumnFamilySchema columnfamily_schema = 3;
- hasColumnfamilySchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- hasColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- hasColumnfamilySchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
required .ColumnFamilySchema columnfamily_schema = 3;
- hasColumnfamilySchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- hasColumnName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
required bytes column_name = 2;
- hasColumnName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
required bytes column_name = 2;
- hasColumnName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequestOrBuilder
-
required bytes column_name = 2;
- hasColumnOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
optional bytes column_offset = 3;
- hasColumnOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
optional bytes column_offset = 3;
- hasColumnOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
-
optional bytes column_offset = 3;
- hasColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
optional bytes column_qualifier = 3;
- hasColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
optional bytes column_qualifier = 3;
- hasColumnQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
-
optional bytes column_qualifier = 3;
- hasColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bytes column_qualifier = 2;
- hasColumnQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
optional bytes column_qualifier = 2;
- hasColumnQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
optional bytes column_qualifier = 2;
- hasColumns() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- hasCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
optional bool compaction_state = 2;
- hasCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
optional bool compaction_state = 2;
- hasCompactionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequestOrBuilder
-
optional bool compaction_state = 2;
- hasCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
optional .GetRegionInfoResponse.CompactionState compaction_state = 2;
- hasCompactionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
optional .GetRegionInfoResponse.CompactionState compaction_state = 2;
- hasCompactionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
-
optional .GetRegionInfoResponse.CompactionState compaction_state = 2;
- hasCompactionTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
-
required int64 compaction_timestamp = 1;
- hasCompactionTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
required int64 compaction_timestamp = 1;
- hasCompactionTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponseOrBuilder
-
required int64 compaction_timestamp = 1;
- hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
required .ByteArrayComparable comparable = 1;
- hasComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparatorOrBuilder
-
required .ByteArrayComparable comparable = 1;
- hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
required .ByteArrayComparable comparable = 1;
- hasComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparatorOrBuilder
-
required .ByteArrayComparable comparable = 1;
- hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
required .ByteArrayComparable comparable = 1;
- hasComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparatorOrBuilder
-
required .ByteArrayComparable comparable = 1;
- hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- hasComparable() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
required .ByteArrayComparable comparable = 1;
- hasComparable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparatorOrBuilder
-
required .ByteArrayComparable comparable = 1;
- hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required .Comparator comparator = 5;
- hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
required .Comparator comparator = 5;
- hasComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
-
required .Comparator comparator = 5;
- hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
optional .Comparator comparator = 2;
- hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
optional .Comparator comparator = 2;
- hasComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilterOrBuilder
-
optional .Comparator comparator = 2;
- hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
required .Comparator comparator = 4;
- hasComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
required .Comparator comparator = 4;
- hasComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
required .Comparator comparator = 4;
- hasComparatorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional string comparator_class_name = 11;
- hasComparatorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional string comparator_class_name = 11;
- hasComparatorClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional string comparator_class_name = 11;
- hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
required .CompareFilter compare_filter = 1;
- hasCompareFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilterOrBuilder
-
required .CompareFilter compare_filter = 1;
- hasCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
required .CompareType compare_op = 1;
- hasCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
required .CompareType compare_op = 1;
- hasCompareOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilterOrBuilder
-
required .CompareType compare_op = 1;
- hasCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
required .CompareType compare_op = 3;
- hasCompareOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
required .CompareType compare_op = 3;
- hasCompareOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
required .CompareType compare_op = 3;
- hasCompareType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required .CompareType compare_type = 4;
- hasCompareType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
required .CompareType compare_type = 4;
- hasCompareType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
-
required .CompareType compare_type = 4;
- hasCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 complete_sequence_id = 15;
- hasCompleteSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint64 complete_sequence_id = 15;
- hasCompleteSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint64 complete_sequence_id = 15;
- hasCompression - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- hasCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- hasCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- hasCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- hasCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional string compression = 5;
- hasCompression() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
optional string compression = 5;
- hasCompression() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
optional string compression = 5;
- hasCompressionCodec() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 compression_codec = 12;
- hasCompressionCodec() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint32 compression_codec = 12;
- hasCompressionCodec() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint32 compression_codec = 12;
- hasCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
optional .Condition condition = 3;
- hasCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
optional .Condition condition = 3;
- hasCondition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
-
optional .Condition condition = 3;
- hasCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
optional .Condition condition = 3;
- hasCondition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
optional .Condition condition = 3;
- hasCondition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
-
optional .Condition condition = 3;
- hasConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .Consistency consistency = 12 [default = STRONG];
- hasConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional .Consistency consistency = 12 [default = STRONG];
- hasConsistency() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional .Consistency consistency = 12 [default = STRONG];
- hasConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .Consistency consistency = 16 [default = STRONG];
- hasConsistency() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional .Consistency consistency = 16 [default = STRONG];
- hasConsistency() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional .Consistency consistency = 16 [default = STRONG];
- hasCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Check if the table has an attached co-processor represented by the name className
- hasCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
-
required int64 count = 1 [default = 0];
- hasCount() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
required int64 count = 1 [default = 0];
- hasCount() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponseOrBuilder
-
required int64 count = 1 [default = 0];
- hasCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required uint64 create_time = 3;
- hasCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
required uint64 create_time = 3;
- hasCreateTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
-
required uint64 create_time = 3;
- hasCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional int64 create_time = 6;
- hasCreateTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional int64 create_time = 6;
- hasCreateTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional int64 create_time = 6;
- hasCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
optional int64 creation_time = 3 [default = 0];
- hasCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
optional int64 creation_time = 3 [default = 0];
- hasCreationTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
optional int64 creation_time = 3 [default = 0];
- hasCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional int64 creation_time = 3 [default = 0];
- hasCreationTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
optional int64 creation_time = 3 [default = 0];
- hasCreationTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
optional int64 creation_time = 3 [default = 0];
- hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 current_compacted_KVs = 11;
- hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint64 current_compacted_KVs = 11;
- hasCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint64 current_compacted_KVs = 11;
- hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 currentCompactedKVs = 13;
- hasCurrentCompactedKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int64 currentCompactedKVs = 13;
- hasCurrentCompactedKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int64 currentCompactedKVs = 13;
- hasData() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required bytes data = 3;
- hasData() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
required bytes data = 3;
- hasData() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
-
required bytes data = 3;
- hasData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional bytes data = 4;
- hasData() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
optional bytes data = 4;
- hasData() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
optional bytes data = 4;
- hasDataIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 data_index_count = 5;
- hasDataIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint32 data_index_count = 5;
- hasDataIndexCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint32 data_index_count = 5;
- hasDataLocality() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional float data_locality = 16;
- hasDataLocality() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional float data_locality = 16;
- hasDataLocality() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional float data_locality = 16;
- hasDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string date = 5;
- hasDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string date = 5;
- hasDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string date = 5;
- hasDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string declaring_class = 1;
- hasDeclaringClass() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
optional string declaring_class = 1;
- hasDeclaringClass() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
optional string declaring_class = 1;
- hasDeleteColumnFamilyInModify() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required bool delete_column_family_in_modify = 4;
- hasDeleteColumnFamilyInModify() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
required bool delete_column_family_in_modify = 4;
- hasDeleteColumnFamilyInModify() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
-
required bool delete_column_family_in_modify = 4;
- hasDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required .BulkDeleteRequest.DeleteType deleteType = 2;
- hasDeleteType() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
required .BulkDeleteRequest.DeleteType deleteType = 2;
- hasDeleteType() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
-
required .BulkDeleteRequest.DeleteType deleteType = 2;
- hasDeleteType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional .MutationProto.DeleteType delete_type = 4;
- hasDeleteType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
optional .MutationProto.DeleteType delete_type = 4;
- hasDeleteType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
-
optional .MutationProto.DeleteType delete_type = 4;
- hasDestinationServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional .ServerName destination_server = 4;
- hasDestinationServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
optional .ServerName destination_server = 4;
- hasDestinationServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
-
optional .ServerName destination_server = 4;
- hasDestServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
optional .ServerName dest_server_name = 2;
- hasDestServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
optional .ServerName dest_server_name = 2;
- hasDestServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequestOrBuilder
-
optional .ServerName dest_server_name = 2;
- hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
optional bool done = 1 [default = false];
- hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
optional bool done = 1 [default = false];
- hasDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponseOrBuilder
-
optional bool done = 1 [default = false];
- hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
-
optional bool done = 1 [default = false];
- hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
optional bool done = 1 [default = false];
- hasDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponseOrBuilder
-
optional bool done = 1 [default = false];
- hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
optional bool done = 1 [default = false];
- hasDone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
optional bool done = 1 [default = false];
- hasDone() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponseOrBuilder
-
optional bool done = 1 [default = false];
- hasDoNotRetry() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional bool do_not_retry = 5;
- hasDoNotRetry() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional bool do_not_retry = 5;
- hasDoNotRetry() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional bool do_not_retry = 5;
- hasDoubleMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
-
required double double_msg = 1;
- hasDoubleMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
required double double_msg = 1;
- hasDoubleMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsgOrBuilder
-
required double double_msg = 1;
- hasDropDependentColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
optional bool drop_dependent_column = 4;
- hasDropDependentColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
optional bool drop_dependent_column = 4;
- hasDropDependentColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilterOrBuilder
-
optional bool drop_dependent_column = 4;
- hasDurability() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .MutationProto.Durability durability = 6 [default = USE_DEFAULT];
- hasDurability() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional .MutationProto.Durability durability = 6 [default = USE_DEFAULT];
- hasDurability() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional .MutationProto.Durability durability = 6 [default = USE_DEFAULT];
- hasEffectiveUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
required string effective_user = 1;
- hasEffectiveUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
required string effective_user = 1;
- hasEffectiveUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformationOrBuilder
-
required string effective_user = 1;
- hasEnable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
-
required bool enable = 1;
- hasEnable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
required bool enable = 1;
- hasEnable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequestOrBuilder
-
required bool enable = 1;
- hasEnabled() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
-
required bool enabled = 1;
- hasEnabled() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
required bool enabled = 1;
- hasEnabled() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponseOrBuilder
-
required bool enabled = 1;
- hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required bytes encoded_region_name = 2;
- hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
required bytes encoded_region_name = 2;
- hasEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
-
required bytes encoded_region_name = 2;
- hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required bytes encoded_region_name = 2;
- hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
required bytes encoded_region_name = 2;
- hasEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
required bytes encoded_region_name = 2;
- hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
required bytes encoded_region_name = 3;
- hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
required bytes encoded_region_name = 3;
- hasEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
required bytes encoded_region_name = 3;
- hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
required bytes encoded_region_name = 3;
- hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
required bytes encoded_region_name = 3;
- hasEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
required bytes encoded_region_name = 3;
- hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required bytes encoded_region_name = 1;
- hasEncodedRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
required bytes encoded_region_name = 1;
- hasEncodedRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
required bytes encoded_region_name = 1;
- hasEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional bytes encryption_key = 13;
- hasEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional bytes encryption_key = 13;
- hasEncryptionKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional bytes encryption_key = 13;
- hasEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional bytes encryption_key = 2;
- hasEncryptionKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
optional bytes encryption_key = 2;
- hasEncryptionKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
-
optional bytes encryption_key = 2;
- hasEndKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bytes end_key = 4;
- hasEndKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
optional bytes end_key = 4;
- hasEndKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
optional bytes end_key = 4;
- hasEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional bytes endKey = 3;
- hasEndKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
optional bytes endKey = 3;
- hasEndKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
optional bytes endKey = 3;
- hasEndRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- hasEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional bytes endRow = 2;
- hasEndRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional bytes endRow = 2;
- hasEndRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional bytes endRow = 2;
- hasEndRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- hasEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int64 endTime = 6;
- hasEndTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional int64 endTime = 6;
- hasEndTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional int64 endTime = 6;
- hasEngine() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
optional string engine = 4;
- hasEngine() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
optional string engine = 4;
- hasEngine() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
-
optional string engine = 4;
- hasEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 entry_count = 7;
- hasEntryCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 entry_count = 7;
- hasEntryCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 entry_count = 7;
- hasError() - Method in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- hasErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional bytes error_info = 3;
- hasErrorInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
optional bytes error_info = 3;
- hasErrorInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
optional bytes error_info = 3;
- hasErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
optional string error_message = 1;
- hasErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
optional string error_message = 1;
- hasErrorMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponseOrBuilder
-
optional string error_message = 1;
- hasErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required string error_message = 2;
- hasErrorMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
required string error_message = 2;
- hasErrorMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
-
required string error_message = 2;
- hasEventType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
required .RegionEventDescriptor.EventType event_type = 1;
- hasEventType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
required .RegionEventDescriptor.EventType event_type = 1;
- hasEventType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
required .RegionEventDescriptor.EventType event_type = 1;
- hasEventTypeCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required uint32 event_type_code = 1;
- hasEventTypeCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
required uint32 event_type_code = 1;
- hasEventTypeCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
-
required uint32 event_type_code = 1;
- hasException() - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
- hasException() - Method in interface org.apache.hadoop.hbase.errorhandling.ForeignExceptionSnare
-
- hasException() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- hasException() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
optional .NameBytesPair exception = 2;
- hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
optional .NameBytesPair exception = 2;
- hasException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResultOrBuilder
-
optional .NameBytesPair exception = 2;
- hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .NameBytesPair exception = 3;
- hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional .NameBytesPair exception = 3;
- hasException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional .NameBytesPair exception = 3;
- hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional .ForeignExceptionMessage exception = 5;
- hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
optional .ForeignExceptionMessage exception = 5;
- hasException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
-
optional .ForeignExceptionMessage exception = 5;
- hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional .ForeignExceptionMessage exception = 10;
- hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional .ForeignExceptionMessage exception = 10;
- hasException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional .ForeignExceptionMessage exception = 10;
- hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .ExceptionResponse exception = 2;
- hasException() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
optional .ExceptionResponse exception = 2;
- hasException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeaderOrBuilder
-
optional .ExceptionResponse exception = 2;
- hasException() - Method in class org.apache.hadoop.hbase.zookeeper.DeletionListener
-
Check if an exception has occurred when re-setting the watch.
- hasExceptionClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string exception_class_name = 1;
- hasExceptionClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional string exception_class_name = 1;
- hasExceptionClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional string exception_class_name = 1;
- hasExecuted() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
-
required bool executed = 1;
- hasExecuted() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
required bool executed = 1;
- hasExecuted() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureDataOrBuilder
-
required bool executed = 1;
- hasExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional bool existence_only = 10 [default = false];
- hasExistenceOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional bool existence_only = 10 [default = false];
- hasExistenceOnly() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional bool existence_only = 10 [default = false];
- hasExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional bool exists = 3;
- hasExists() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
optional bool exists = 3;
- hasExists() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
optional bool exists = 3;
- hasExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
optional int64 expected_timeout = 1;
- hasExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
optional int64 expected_timeout = 1;
- hasExpectedTimeout() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponseOrBuilder
-
optional int64 expected_timeout = 1;
- hasExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
-
required int64 expected_timeout = 1;
- hasExpectedTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
required int64 expected_timeout = 1;
- hasExpectedTimeout() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponseOrBuilder
-
required int64 expected_timeout = 1;
- hasExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
required int64 expiration_date = 2;
- hasExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
required int64 expiration_date = 2;
- hasExpirationDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
-
required int64 expiration_date = 2;
- hasExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
optional int64 expiration_date = 5;
- hasExpirationDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
optional int64 expiration_date = 5;
- hasExpirationDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
-
optional int64 expiration_date = 5;
- hasExpression() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
required string expression = 1;
- hasExpression() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
required string expression = 1;
- hasExpression() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibilityOrBuilder
-
required string expression = 1;
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.Get
-
Method for checking if any families have been inserted into this Get
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.Increment
-
Method for checking if any families have been inserted into this Increment
- hasFamilies() - Method in class org.apache.hadoop.hbase.client.Scan
-
- hasFamily(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Checks to see if this table contains the given column family
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional bytes family = 2;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
optional bytes family = 2;
- hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
-
optional bytes family = 2;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
optional bytes family = 3;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
optional bytes family = 3;
- hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
-
optional bytes family = 3;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes family = 2;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional bytes family = 2;
- hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional bytes family = 2;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
required bytes family = 2;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
required bytes family = 2;
- hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
required bytes family = 2;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
required bytes family = 1;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
required bytes family = 1;
- hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder
-
required bytes family = 1;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
required bytes family = 1;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
required bytes family = 1;
- hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ColumnOrBuilder
-
required bytes family = 1;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required bytes family = 2;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
required bytes family = 2;
- hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
-
required bytes family = 2;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
required bytes family = 1;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
required bytes family = 1;
- hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValueOrBuilder
-
required bytes family = 1;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
required bytes family = 1;
- hasFamily() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
required bytes family = 1;
- hasFamily() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScopeOrBuilder
-
required bytes family = 1;
- hasFamily() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
required bytes family_name = 1;
- hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
required bytes family_name = 1;
- hasFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceIdOrBuilder
-
required bytes family_name = 1;
- hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
required bytes family_name = 1;
- hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
required bytes family_name = 1;
- hasFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFilesOrBuilder
-
required bytes family_name = 1;
- hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required bytes family_name = 3;
- hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
required bytes family_name = 3;
- hasFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
required bytes family_name = 3;
- hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
required bytes family_name = 1;
- hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
required bytes family_name = 1;
- hasFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptorOrBuilder
-
required bytes family_name = 1;
- hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
required bytes family_name = 1;
- hasFamilyName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
required bytes family_name = 1;
- hasFamilyName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptorOrBuilder
-
required bytes family_name = 1;
- hasFamilyStamp - Variable in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
- hasFan() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- hasFileInfoOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 file_info_offset = 1;
- hasFileInfoOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 file_info_offset = 1;
- hasFileInfoOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 file_info_offset = 1;
- hasFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string file_name = 3;
- hasFileName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
optional string file_name = 3;
- hasFileName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
optional string file_name = 3;
- hasFileSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
optional uint64 file_size = 3;
- hasFileSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
optional uint64 file_size = 3;
- hasFileSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFileOrBuilder
-
optional uint64 file_size = 3;
- hasFilter() - Method in class org.apache.hadoop.hbase.client.Scan
-
- hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .Filter filter = 4;
- hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional .Filter filter = 4;
- hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional .Filter filter = 4;
- hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .Filter filter = 5;
- hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional .Filter filter = 5;
- hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional .Filter filter = 5;
- hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
required .Filter filter = 1;
- hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
required .Filter filter = 1;
- hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapperOrBuilder
-
required .Filter filter = 1;
- hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
required .Filter filter = 1;
- hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
required .Filter filter = 1;
- hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilterOrBuilder
-
required .Filter filter = 1;
- hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
required .Filter filter = 1;
- hasFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
required .Filter filter = 1;
- hasFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilterOrBuilder
-
required .Filter filter = 1;
- hasFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional string filter = 8;
- hasFilter() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional string filter = 8;
- hasFilter() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional string filter = 8;
- hasFilterIfMissing() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bool filter_if_missing = 5;
- hasFilterIfMissing() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
optional bool filter_if_missing = 5;
- hasFilterIfMissing() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
optional bool filter_if_missing = 5;
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.Filter
-
Primarily used to check for conflicts with scans(such as scans that do not read a full row at a
time).
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterBase
-
Fitlers that never filter by modifying the returned List of Cells can
inherit this implementation that does nothing.
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.PageFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.SkipFilter
-
- hasFilterRow() - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
-
- hasFirst() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
required bytes first = 1;
- hasFirst() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
required bytes first = 1;
- hasFirst() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPairOrBuilder
-
required bytes first = 1;
- hasFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 first_data_block_offset = 9;
- hasFirstDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 first_data_block_offset = 9;
- hasFirstDataBlockOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 first_data_block_offset = 9;
- hasFlushed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
optional bool flushed = 2;
- hasFlushed() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
optional bool flushed = 2;
- hasFlushed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
-
optional bool flushed = 2;
- hasFlushSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
optional uint64 flush_sequence_number = 4;
- hasFlushSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
optional uint64 flush_sequence_number = 4;
- hasFlushSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
optional uint64 flush_sequence_number = 4;
- hasFollowingKvCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint32 following_kv_count = 7;
- hasFollowingKvCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
optional uint32 following_kv_count = 7;
- hasFollowingKvCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
optional uint32 following_kv_count = 7;
- hasForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
optional bool force = 2 [default = false];
- hasForce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
optional bool force = 2 [default = false];
- hasForce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequestOrBuilder
-
optional bool force = 2 [default = false];
- hasForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
optional bool forcible = 3 [default = false];
- hasForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
optional bool forcible = 3 [default = false];
- hasForcible() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
-
optional bool forcible = 3 [default = false];
- hasForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
optional bool forcible = 3 [default = false];
- hasForcible() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
optional bool forcible = 3 [default = false];
- hasForcible() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequestOrBuilder
-
optional bool forcible = 3 [default = false];
- hasFoundKV() - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- hasFreeSpace() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- hasFrom() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
optional uint64 from = 1;
- hasFrom() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
optional uint64 from = 1;
- hasFrom() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRangeOrBuilder
-
optional uint64 from = 1;
- hasFsToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required .DelegationToken fs_token = 3;
- hasFsToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
required .DelegationToken fs_token = 3;
- hasFsToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder
-
required .DelegationToken fs_token = 3;
- hasGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional .GenericExceptionMessage generic_exception = 2;
- hasGenericException() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
optional .GenericExceptionMessage generic_exception = 2;
- hasGenericException() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
-
optional .GenericExceptionMessage generic_exception = 2;
- hasGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .Get get = 3;
- hasGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
optional .Get get = 3;
- hasGet() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
-
optional .Get get = 3;
- hasGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .Get get = 2;
- hasGet() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
required .Get get = 2;
- hasGet() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
-
required .Get get = 2;
- hasGlobalPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .GlobalPermission global_permission = 2;
- hasGlobalPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
optional .GlobalPermission global_permission = 2;
- hasGlobalPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
-
optional .GlobalPermission global_permission = 2;
- hash - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
The hash value for this entries key
- hash - Variable in class org.apache.hadoop.hbase.util.AbstractByteRange
-
Variable for lazy-caching the hashCode of this range.
- hash - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Hash Function
- Hash - Class in org.apache.hadoop.hbase.util
-
This class represents a common API for hashing functions.
- Hash() - Constructor for class org.apache.hadoop.hbase.util.Hash
-
- hash(byte[]) - Method in class org.apache.hadoop.hbase.util.Hash
-
Calculate a hash using all bytes from the input argument, and
a seed of -1.
- hash(byte[], int) - Method in class org.apache.hadoop.hbase.util.Hash
-
Calculate a hash using all bytes from the input argument,
and a provided seed value.
- hash(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.Hash
-
Calculate a hash using bytes from 0 to length
, and
the provided seed value
- hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.Hash
-
Calculate a hash using bytes from offset
to offset +
length
, and the provided seed value.
- hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.JenkinsHash
-
taken from hashlittle() -- hash a variable-length key into a 32-bit value
- hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.MurmurHash
-
- hash(byte[], int, int, int) - Method in class org.apache.hadoop.hbase.util.MurmurHash3
-
Returns the MurmurHash3_x86_32 hash.
- hash128(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the MD5 digest of the concatenation of the supplied arguments.
- hash128(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the MD5 digest of the concatenation of the supplied arguments.
- hash256(String...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the SHA-256 digest of the concatenation of the supplied arguments.
- hash256(byte[]...) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Return the SHA-256 digest of the concatenation of the supplied arguments.
- HASH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- HASH_NONCE_GRACE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
- hasHasCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional bool has_compression = 1;
- hasHasCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
optional bool has_compression = 1;
- hasHasCompression() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
-
optional bool has_compression = 1;
- hasHash() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
optional bytes hash = 5;
- hasHash() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
optional bytes hash = 5;
- hasHash() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
-
optional bytes hash = 5;
- hasHasTagCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional bool has_tag_compression = 3;
- hasHasTagCompression() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
optional bool has_tag_compression = 3;
- hasHasTagCompression() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
-
optional bool has_tag_compression = 3;
- hasHbaseVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .HBaseVersionFileContent hbase_version = 1;
- hasHbaseVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
optional .HBaseVersionFileContent hbase_version = 1;
- hasHbaseVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
optional .HBaseVersionFileContent hbase_version = 1;
- hashCode(Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
-
Returns a hash code that is always the same for two Cells having a matching equals(..) result.
- hashCode() - Method in class org.apache.hadoop.hbase.client.Action
-
- hashCode() - Method in class org.apache.hadoop.hbase.client.Get
-
- hashCode() - Method in class org.apache.hadoop.hbase.client.Increment
-
- hashCode() - Method in class org.apache.hadoop.hbase.client.RegionCoprocessorServiceExec
-
- hashCode() - Method in class org.apache.hadoop.hbase.client.RowMutations
-
- hashCode() - Method in class org.apache.hadoop.hbase.ClusterStatus
-
- hashCode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- hashCode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- hashCode() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
Generated by Eclipse
- hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.filter.NullComparator
-
- hashCode() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.HRegionLocation
-
- hashCode() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.io.FileLink
-
- hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
- hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- hashCode() - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- hashCode() - Method in class org.apache.hadoop.hbase.io.Reference
-
- hashCode() - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
-
- hashCode() - Method in class org.apache.hadoop.hbase.ipc.ConnectionId
-
- hashCode(User, String, InetSocketAddress) - Static method in class org.apache.hadoop.hbase.ipc.ConnectionId
-
- hashCode() - Method in class org.apache.hadoop.hbase.KeyValue
-
- hashCode() - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
- hashCode() - Method in class org.apache.hadoop.hbase.mapred.TableSplit
-
- hashCode() - Method in class org.apache.hadoop.hbase.mapreduce.TableSplit
-
- hashCode() - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodesPlan
-
- hashCode() - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
- hashCode() - Method in class org.apache.hadoop.hbase.master.RegionState
-
Don't count timestamp in hash code calculation
- hashCode() - Method in class org.apache.hadoop.hbase.procedure.ProcedureManager
-
- hashCode() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateConfigurationResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.NullComparator
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterAllFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyOnlyFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.EmptyMsg
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ShutdownResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.StopMasterResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationProcessorResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotaUsage
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALTrailer
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
- hashCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns the hash code of the entry by xor'ing the hash values
of the key and value of this entry.
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Intentionally unimplemented.
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
-
- hashCode() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.access.Permission
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.access.UserPermission
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.User
-
- hashCode() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- hashCode() - Method in class org.apache.hadoop.hbase.ServerName
-
- hashCode() - Method in class org.apache.hadoop.hbase.SplitLogTask
-
- hashCode() - Method in class org.apache.hadoop.hbase.TableName
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.CallQueue.Call
-
- hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- hashCode() - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- hashCode() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- hashCode() - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- hashCode() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- hashCode() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- hashCode(byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- hashCode(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- hashCode(byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- hashCode() - Method in class org.apache.hadoop.hbase.util.HashedBytes
-
- hashCode() - Method in class org.apache.hadoop.hbase.util.NonceKey
-
- hashCode() - Method in class org.apache.hadoop.hbase.util.Pair
-
- hashCode() - Method in class org.apache.hadoop.hbase.util.PairOfSameType
-
- hashCode() - Method in class org.apache.hadoop.hbase.util.Triple
-
- hashCode() - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.CreateAndFailSilent
-
- hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.DeleteNodeFailSilent
-
- hashCode() - Method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp.SetData
-
- hashCode() - Method in class org.apache.hadoop.metrics2.util.MetricQuantile
-
- hashCodeIgnoreMvcc(Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
-
Returns a hash code that is always the same for two Cells having a matching
equals(..) result.
- hashCount - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Number of hash functions
- hasHeapOccupancy() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
optional int32 heapOccupancy = 2 [default = 0];
- hasHeapOccupancy() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
optional int32 heapOccupancy = 2 [default = 0];
- hasHeapOccupancy() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStatsOrBuilder
-
optional int32 heapOccupancy = 2 [default = 0];
- hasHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int32 heapSizeMB = 4;
- hasHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
optional int32 heapSizeMB = 4;
- hasHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
optional int32 heapSizeMB = 4;
- hasHeartbeatMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool heartbeat_message = 9;
- hasHeartbeatMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
optional bool heartbeat_message = 9;
- hasHeartbeatMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
optional bool heartbeat_message = 9;
- HashedBytes - Class in org.apache.hadoop.hbase.util
-
This class encapsulates a byte array and overrides hashCode and equals so
that it's identity is based on the data rather than the array instance.
- HashedBytes(byte[]) - Constructor for class org.apache.hadoop.hbase.util.HashedBytes
-
- hasHfile() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string hfile = 3;
- hasHfile() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
optional string hfile = 3;
- hasHfile() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
-
optional string hfile = 3;
- hasHigherPriority(ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.filter.ParseFilter
-
Returns which operator has higher precedence
- hasHostName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
required string host_name = 1;
- hasHostName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
required string host_name = 1;
- hasHostName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
-
required string host_name = 1;
- hasHostname() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string hostname = 3;
- hasHostname() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional string hostname = 3;
- hasHostname() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional string hostname = 3;
- hashType - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Hash type
- hashType - Variable in class org.apache.hadoop.hbase.util.CompoundBloomFilterBase
-
Hash function type to use, as defined in
Hash
- hasId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
required int32 id = 1;
- hasId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
required int32 id = 1;
- hasId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
-
required int32 id = 1;
- hasId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional int64 id = 4;
- hasId() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
optional int64 id = 4;
- hasId() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
optional int64 id = 4;
- hasId() - Method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
- hasIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
optional bytes identifier = 1;
- hasIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
optional bytes identifier = 1;
- hasIdentifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
-
optional bytes identifier = 1;
- hasIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional bytes identifier = 1;
- hasIdentifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
optional bytes identifier = 1;
- hasIdentifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
-
optional bytes identifier = 1;
- hasIfOlderThanTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
optional uint64 if_older_than_ts = 2;
- hasIfOlderThanTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
optional uint64 if_older_than_ts = 2;
- hasIfOlderThanTs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
-
optional uint64 if_older_than_ts = 2;
- hasIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional bool include_sys_tables = 3 [default = false];
- hasIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
optional bool include_sys_tables = 3 [default = false];
- hasIncludeSysTables() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
optional bool include_sys_tables = 3 [default = false];
- hasIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional bool include_sys_tables = 2 [default = false];
- hasIncludeSysTables() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
optional bool include_sys_tables = 2 [default = false];
- hasIncludeSysTables() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequestOrBuilder
-
optional bool include_sys_tables = 2 [default = false];
- hasIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional uint32 index = 1;
- hasIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
optional uint32 index = 1;
- hasIndex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
-
optional uint32 index = 1;
- hasIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional uint32 index = 1;
- hasIndex() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional uint32 index = 1;
- hasIndex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional uint32 index = 1;
- hasInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
optional int32 infoPort = 1;
- hasInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo
-
optional int32 infoPort = 1;
- hasInfoPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfoOrBuilder
-
optional int32 infoPort = 1;
- hasInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
optional uint32 info_port = 3;
- hasInfoPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
optional uint32 info_port = 3;
- hasInfoPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
-
optional uint32 info_port = 3;
- hasInfoServerPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint32 info_server_port = 9;
- hasInfoServerPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint32 info_server_port = 9;
- hasInfoServerPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint32 info_server_port = 9;
- hasInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional bool inMemory = 4;
- hasInMemory() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
optional bool inMemory = 4;
- hasInMemory() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
optional bool inMemory = 4;
- hasInstance() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
optional string instance = 2;
- hasInstance() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
optional string instance = 2;
- hasInstance() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
optional string instance = 2;
- hasInterpreterClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required string interpreter_class_name = 1;
- hasInterpreterClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
required string interpreter_class_name = 1;
- hasInterpreterClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequestOrBuilder
-
required string interpreter_class_name = 1;
- hasInterpreterSpecificBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
optional bytes interpreter_specific_bytes = 3;
- hasInterpreterSpecificBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
optional bytes interpreter_specific_bytes = 3;
- hasInterpreterSpecificBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequestOrBuilder
-
optional bytes interpreter_specific_bytes = 3;
- hasIsMasterRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
-
required bool is_master_running = 1;
- hasIsMasterRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse
-
required bool is_master_running = 1;
- hasIsMasterRunning() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponseOrBuilder
-
required bool is_master_running = 1;
- hasIsProcedureAborted() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
-
required bool is_procedure_aborted = 1;
- hasIsProcedureAborted() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse
-
required bool is_procedure_aborted = 1;
- hasIsProcedureAborted() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponseOrBuilder
-
required bool is_procedure_aborted = 1;
- hasIsRecovering() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
optional bool isRecovering = 3;
- hasIsRecovering() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
optional bool isRecovering = 3;
- hasIsRecovering() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
-
optional bool isRecovering = 3;
- hasIsShared() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional bool is_shared = 4;
- hasIsShared() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional bool is_shared = 4;
- hasIsShared() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional bool is_shared = 4;
- hasIssueDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
optional int64 issue_date = 4;
- hasIssueDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
optional int64 issue_date = 4;
- hasIssueDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
-
optional int64 issue_date = 4;
- hasIv() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
optional bytes iv = 4;
- hasIv() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
optional bytes iv = 4;
- hasIv() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
-
optional bytes iv = 4;
- hasJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string jerseyVersion = 5;
- hasJerseyVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string jerseyVersion = 5;
- hasJerseyVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string jerseyVersion = 5;
- hasJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string jvmVersion = 2;
- hasJvmVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string jvmVersion = 2;
- hasJvmVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string jvmVersion = 2;
- hasKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
required .WALKey key = 1;
- hasKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
required .WALKey key = 1;
- hasKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntryOrBuilder
-
required .WALKey key = 1;
- hasKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
required bytes key = 3;
- hasKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
-
required bytes key = 3;
- hasKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKeyOrBuilder
-
required bytes key = 3;
- hasKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
required bytes key = 1;
- hasKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
-
required bytes key = 1;
- hasKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.RowOrBuilder
-
required bytes key = 1;
- hasKeyId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
required int32 key_id = 3;
- hasKeyId() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
required int32 key_id = 3;
- hasKeyId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
-
required int32 key_id = 3;
- hasKeyType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional .CellType key_type = 5;
- hasKeyType() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
optional .CellType key_type = 5;
- hasKeyType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
optional .CellType key_type = 5;
- hasKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
required .TokenIdentifier.Kind kind = 1;
- hasKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
required .TokenIdentifier.Kind kind = 1;
- hasKind() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
-
required .TokenIdentifier.Kind kind = 1;
- hasKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional string kind = 3;
- hasKind() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
optional string kind = 3;
- hasKind() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
-
optional string kind = 3;
- hasLabel() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
required bytes label = 1;
- hasLabel() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
required bytes label = 1;
- hasLabel() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelOrBuilder
-
required bytes label = 1;
- hasLabels() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- hasLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 last_data_block_offset = 10;
- hasLastDataBlockOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 last_data_block_offset = 10;
- hasLastDataBlockOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 last_data_block_offset = 10;
- hasLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
required uint64 last_flushed_sequence_id = 1;
- hasLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
required uint64 last_flushed_sequence_id = 1;
- hasLastFlushedSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIdsOrBuilder
-
required uint64 last_flushed_sequence_id = 1;
- hasLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
required uint64 last_flushed_sequence_id = 1;
- hasLastFlushedSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
required uint64 last_flushed_sequence_id = 1;
- hasLastFlushedSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponseOrBuilder
-
required uint64 last_flushed_sequence_id = 1;
- hasLastFlushTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
required uint64 last_flush_time = 1;
- hasLastFlushTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
required uint64 last_flush_time = 1;
- hasLastFlushTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
-
required uint64 last_flush_time = 1;
- hasLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 last_major_compaction_ts = 17 [default = 0];
- hasLastMajorCompactionTs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint64 last_major_compaction_ts = 17 [default = 0];
- hasLastMajorCompactionTs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint64 last_major_compaction_ts = 17 [default = 0];
- hasLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional uint64 last_update = 3;
- hasLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
optional uint64 last_update = 3;
- hasLastUpdate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
-
optional uint64 last_update = 3;
- hasLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required uint64 last_update = 8;
- hasLastUpdate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
required uint64 last_update = 8;
- hasLastUpdate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
required uint64 last_update = 8;
- hasLatestVersionOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bool latest_version_only = 6;
- hasLatestVersionOnly() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter
-
optional bool latest_version_only = 6;
- hasLatestVersionOnly() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilterOrBuilder
-
optional bool latest_version_only = 6;
- hasLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
- hasLeastSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
required uint64 least_sig_bits = 1;
- hasLeastSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
required uint64 least_sig_bits = 1;
- hasLeastSigBits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUIDOrBuilder
-
required uint64 least_sig_bits = 1;
- hasLenAsVal() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
-
required bool len_as_val = 1;
- hasLenAsVal() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter
-
required bool len_as_val = 1;
- hasLenAsVal() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilterOrBuilder
-
required bool len_as_val = 1;
- hasLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required uint32 length = 2;
- hasLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
required uint32 length = 2;
- hasLength() - Method in interface org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKeyOrBuilder
-
required uint32 length = 2;
- hasLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
-
optional uint32 length = 1;
- hasLength() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta
-
optional uint32 length = 1;
- hasLength() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMetaOrBuilder
-
optional uint32 length = 1;
- hasLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
-
required int32 limit = 1;
- hasLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter
-
required int32 limit = 1;
- hasLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilterOrBuilder
-
required int32 limit = 1;
- hasLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
required int32 limit = 1;
- hasLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
required int32 limit = 1;
- hasLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
-
required int32 limit = 1;
- hasLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional int32 line_number = 4;
- hasLineNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
optional int32 line_number = 4;
- hasLineNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
optional int32 line_number = 4;
- hasLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
optional .ServerLoad load = 2;
- hasLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
optional .ServerLoad load = 2;
- hasLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
-
optional .ServerLoad load = 2;
- hasLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool load_column_families_on_demand = 13;
- hasLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bool load_column_families_on_demand = 13;
- hasLoadColumnFamiliesOnDemand() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bool load_column_families_on_demand = 13;
- hasLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
-
required bool loaded = 1;
- hasLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse
-
required bool loaded = 1;
- hasLoaded() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponseOrBuilder
-
required bool loaded = 1;
- hasLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
-
required bool loaded = 1;
- hasLoaded() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse
-
required bool loaded = 1;
- hasLoaded() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponseOrBuilder
-
required bool loaded = 1;
- hasLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 load_on_open_data_offset = 2;
- hasLoadOnOpenDataOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 load_on_open_data_offset = 2;
- hasLoadOnOpenDataOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 load_on_open_data_offset = 2;
- hasLoadStats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .RegionLoadStats loadStats = 5;
- hasLoadStats() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional .RegionLoadStats loadStats = 5;
- hasLoadStats() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional .RegionLoadStats loadStats = 5;
- hasLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional string location = 5;
- hasLocation() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
optional string location = 5;
- hasLocation() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
optional string location = 5;
- hasLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
required string lock_owner = 1;
- hasLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock
-
required string lock_owner = 1;
- hasLockOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLockOrBuilder
-
required string lock_owner = 1;
- hasLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .ServerName lock_owner = 2;
- hasLockOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional .ServerName lock_owner = 2;
- hasLockOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional .ServerName lock_owner = 2;
- hasLogId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint64 log_id = 3;
- hasLogId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
required uint64 log_id = 3;
- hasLogId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeaderOrBuilder
-
required uint64 log_id = 3;
- hasLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional uint64 log_sequence_number = 4;
- hasLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
optional uint64 log_sequence_number = 4;
- hasLogSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
optional uint64 log_sequence_number = 4;
- hasLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required uint64 log_sequence_number = 3;
- hasLogSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
required uint64 log_sequence_number = 3;
- hasLogSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
required uint64 log_sequence_number = 3;
- hasLongMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
-
required int64 long_msg = 1;
- hasLongMsg() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg
-
required int64 long_msg = 1;
- hasLongMsg() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsgOrBuilder
-
required int64 long_msg = 1;
- hasMajor() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
optional bool major = 2;
- hasMajor() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
optional bool major = 2;
- hasMajor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
-
optional bool major = 2;
- hasMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ServerName master = 7;
- hasMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
optional .ServerName master = 7;
- hasMaster() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatusOrBuilder
-
optional .ServerName master = 7;
- hasMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
required .ServerName master = 1;
- hasMaster() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
required .ServerName master = 1;
- hasMaster() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
-
required .ServerName master = 1;
- hasMaster() - Method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Check if there is a master available.
- hasMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
optional uint64 master_system_time = 4;
- hasMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
optional uint64 master_system_time = 4;
- hasMasterSystemTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
-
optional uint64 master_system_time = 4;
- hasMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
optional uint64 master_system_time = 5;
- hasMasterSystemTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
optional uint64 master_system_time = 5;
- hasMasterSystemTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
-
optional uint64 master_system_time = 5;
- hasMaxColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bytes max_column = 3;
- hasMaxColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
optional bytes max_column = 3;
- hasMaxColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
-
optional bytes max_column = 3;
- hasMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bool max_column_inclusive = 4;
- hasMaxColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
optional bool max_column_inclusive = 4;
- hasMaxColumnInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
-
optional bool max_column_inclusive = 4;
- hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint32 max_heap_MB = 4;
- hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint32 max_heap_MB = 4;
- hasMaxHeapMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint32 max_heap_MB = 4;
- hasMaxHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- hasMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int32 maxHeapSizeMB = 5;
- hasMaxHeapSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
optional int32 maxHeapSizeMB = 5;
- hasMaxHeapSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
optional int32 maxHeapSizeMB = 5;
- hasMaxResultSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint64 max_result_size = 10;
- hasMaxResultSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional uint64 max_result_size = 10;
- hasMaxResultSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional uint64 max_result_size = 10;
- hasMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional uint32 max_versions = 6 [default = 1];
- hasMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional uint32 max_versions = 6 [default = 1];
- hasMaxVersions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional uint32 max_versions = 6 [default = 1];
- hasMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 max_versions = 7 [default = 1];
- hasMaxVersions() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional uint32 max_versions = 7 [default = 1];
- hasMaxVersions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional uint32 max_versions = 7 [default = 1];
- hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional int32 maxVersions = 4;
- hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
optional int32 maxVersions = 4;
- hasMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
optional int32 maxVersions = 4;
- hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int32 maxVersions = 7;
- hasMaxVersions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional int32 maxVersions = 7;
- hasMaxVersions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional int32 maxVersions = 7;
- hasMayInterruptIfRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
optional bool mayInterruptIfRunning = 2 [default = true];
- hasMayInterruptIfRunning() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
optional bool mayInterruptIfRunning = 2 [default = true];
- hasMayInterruptIfRunning() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequestOrBuilder
-
optional bool mayInterruptIfRunning = 2 [default = true];
- hasMemstoreLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
optional int32 memstoreLoad = 1 [default = 0];
- hasMemstoreLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
optional int32 memstoreLoad = 1 [default = 0];
- hasMemstoreLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStatsOrBuilder
-
optional int32 memstoreLoad = 1 [default = 0];
- hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 memstore_size_MB = 6;
- hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 memstore_size_MB = 6;
- hasMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 memstore_size_MB = 6;
- hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 memstoreSizeMB = 5;
- hasMemstoreSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 memstoreSizeMB = 5;
- hasMemstoreSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 memstoreSizeMB = 5;
- hasMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional string message = 2;
- hasMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage
-
optional string message = 2;
- hasMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessageOrBuilder
-
optional string message = 2;
- hasMetaIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 meta_index_count = 6;
- hasMetaIndexCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint32 meta_index_count = 6;
- hasMetaIndexCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint32 meta_index_count = 6;
- hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required string method_name = 3;
- hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
required string method_name = 3;
- hasMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
-
required string method_name = 3;
- hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string method_name = 2;
- hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
optional string method_name = 2;
- hasMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessageOrBuilder
-
optional string method_name = 2;
- hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional string method_name = 3;
- hasMethodName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional string method_name = 3;
- hasMethodName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional string method_name = 3;
- hasMinColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bytes min_column = 1;
- hasMinColumn() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
optional bytes min_column = 1;
- hasMinColumn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
-
optional bytes min_column = 1;
- hasMinColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bool min_column_inclusive = 2;
- hasMinColumnInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter
-
optional bool min_column_inclusive = 2;
- hasMinColumnInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilterOrBuilder
-
optional bool min_column_inclusive = 2;
- hasMinimumVersion(RPCProtos.VersionInfo, int, int) - Static method in class org.apache.hadoop.hbase.client.VersionInfoUtil
-
- hasMinProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint64 min_proc_id = 4;
- hasMinProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
required uint64 min_proc_id = 4;
- hasMinProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeaderOrBuilder
-
required uint64 min_proc_id = 4;
- hasMode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN];
- hasMode() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN];
- hasMode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
-
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN];
- hasModifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .TableSchema modified_table_schema = 3;
- hasModifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
required .TableSchema modified_table_schema = 3;
- hasModifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
-
required .TableSchema modified_table_schema = 3;
- hasMoreFanNodes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- hasMoreResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool more_results = 3;
- hasMoreResults() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
optional bool more_results = 3;
- hasMoreResults() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
optional bool more_results = 3;
- hasMoreResultsContext() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Did the server respond with information about whether more results might exist.
- hasMoreResultsInRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool more_results_in_region = 8;
- hasMoreResultsInRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
optional bool more_results_in_region = 8;
- hasMoreResultsInRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
optional bool more_results_in_region = 8;
- hasMoreValues() - Method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
- hasMoreValues(ScannerContext.NextState) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
-
- hasMostSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
required uint64 most_sig_bits = 2;
- hasMostSigBits() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID
-
required uint64 most_sig_bits = 2;
- hasMostSigBits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUIDOrBuilder
-
required uint64 most_sig_bits = 2;
- hasMutateType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .MutationProto.MutationType mutate_type = 2;
- hasMutateType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional .MutationProto.MutationType mutate_type = 2;
- hasMutateType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional .MutationProto.MutationType mutate_type = 2;
- hasMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .MutationProto mutation = 2;
- hasMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
optional .MutationProto mutation = 2;
- hasMutation() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
-
optional .MutationProto mutation = 2;
- hasMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .MutationProto mutation = 2;
- hasMutation() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
required .MutationProto mutation = 2;
- hasMutation() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
-
required .MutationProto mutation = 2;
- hasMVCCInfo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Reader
-
- hasMVCCInfo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
required string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ComparatorOrBuilder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
required string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterOrBuilder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
required bytes name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
required bytes name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchemaOrBuilder
-
required bytes name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor
-
required string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.CoprocessorOrBuilder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
required string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPairOrBuilder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
optional string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
optional string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64PairOrBuilder
-
optional string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
required bytes name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor
-
required bytes name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptorOrBuilder
-
required bytes name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
required string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPairOrBuilder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
required string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
required string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFileOrBuilder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
required string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
optional string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
optional string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
required string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
required bytes name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
required bytes name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
required bytes name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
required string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
required string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfoOrBuilder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
required string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
-
required string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional string name = 1;
- hasName() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
optional string name = 1;
- hasName() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
optional string name = 1;
- hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
required bytes namespace = 1;
- hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
required bytes namespace = 1;
- hasNamespace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableNameOrBuilder
-
required bytes namespace = 1;
- hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional string namespace = 4;
- hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
optional string namespace = 4;
- hasNamespace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
optional string namespace = 4;
- hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional string namespace = 3;
- hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
optional string namespace = 3;
- hasNamespace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequestOrBuilder
-
optional string namespace = 3;
- hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string namespace = 3;
- hasNamespace() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional string namespace = 3;
- hasNamespace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional string namespace = 3;
- hasNamespace() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- hasNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- hasNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- hasNamespaceDescriptor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequestOrBuilder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- hasNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- hasNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- hasNamespaceDescriptor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponseOrBuilder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- hasNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- hasNamespaceDescriptor() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- hasNamespaceDescriptor() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequestOrBuilder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional bytes namespace_name = 3;
- hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
optional bytes namespace_name = 3;
- hasNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequestOrBuilder
-
optional bytes namespace_name = 3;
- hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
optional bytes namespace_name = 1;
- hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
optional bytes namespace_name = 1;
- hasNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermissionOrBuilder
-
optional bytes namespace_name = 1;
- hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
required string namespaceName = 1;
- hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest
-
required string namespaceName = 1;
- hasNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequestOrBuilder
-
required string namespaceName = 1;
- hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
required string namespaceName = 1;
- hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest
-
required string namespaceName = 1;
- hasNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequestOrBuilder
-
required string namespaceName = 1;
- hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
required string namespaceName = 1;
- hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest
-
required string namespaceName = 1;
- hasNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequestOrBuilder
-
required string namespaceName = 1;
- hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
required string namespaceName = 1;
- hasNamespaceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest
-
required string namespaceName = 1;
- hasNamespaceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequestOrBuilder
-
required string namespaceName = 1;
- hasNamespacePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .NamespacePermission namespace_permission = 3;
- hasNamespacePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
optional .NamespacePermission namespace_permission = 3;
- hasNamespacePermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
-
optional .NamespacePermission namespace_permission = 3;
- hasNext() - Method in class org.apache.hadoop.hbase.rest.RowResultGenerator
-
- hasNext() - Method in class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- hasNext() - Method in class org.apache.hadoop.hbase.types.StructIterator
-
- hasNext() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists.Iterator
-
- hasNextCallSeq() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional uint64 next_call_seq = 6;
- hasNextCallSeq() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional uint64 next_call_seq = 6;
- hasNextCallSeq() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional uint64 next_call_seq = 6;
- hasNonce() - Method in class org.apache.hadoop.hbase.client.Action
-
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional uint64 nonce = 9;
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional uint64 nonce = 9;
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional uint64 nonce = 9;
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequestOrBuilder
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequestOrBuilder
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequestOrBuilder
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
optional uint64 nonce = 3 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
optional uint64 nonce = 3 [default = 0];
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequestOrBuilder
-
optional uint64 nonce = 3 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
optional uint64 nonce = 3 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
optional uint64 nonce = 3 [default = 0];
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequestOrBuilder
-
optional uint64 nonce = 3 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
optional uint64 nonce = 3 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
optional uint64 nonce = 3 [default = 0];
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequestOrBuilder
-
optional uint64 nonce = 3 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequestOrBuilder
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequestOrBuilder
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequestOrBuilder
-
optional uint64 nonce = 4 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
optional uint64 nonce = 3;
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
optional uint64 nonce = 3;
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequestOrBuilder
-
optional uint64 nonce = 3;
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint64 nonce = 14 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional uint64 nonce = 14 [default = 0];
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional uint64 nonce = 14 [default = 0];
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional uint64 nonce = 5;
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
optional uint64 nonce = 5;
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
-
optional uint64 nonce = 5;
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint64 nonce = 10;
- hasNonce() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
optional uint64 nonce = 10;
- hasNonce() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
optional uint64 nonce = 10;
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
optional uint64 nonceGroup = 2;
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest
-
optional uint64 nonceGroup = 2;
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequestOrBuilder
-
optional uint64 nonceGroup = 2;
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
optional uint64 nonce_group = 4;
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
optional uint64 nonce_group = 4;
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
-
optional uint64 nonce_group = 4;
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequestOrBuilder
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequestOrBuilder
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequestOrBuilder
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
optional uint64 nonce_group = 2 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
optional uint64 nonce_group = 2 [default = 0];
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequestOrBuilder
-
optional uint64 nonce_group = 2 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
optional uint64 nonce_group = 2 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
optional uint64 nonce_group = 2 [default = 0];
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequestOrBuilder
-
optional uint64 nonce_group = 2 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
optional uint64 nonce_group = 2 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
optional uint64 nonce_group = 2 [default = 0];
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequestOrBuilder
-
optional uint64 nonce_group = 2 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequestOrBuilder
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequestOrBuilder
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequestOrBuilder
-
optional uint64 nonce_group = 3 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
optional uint64 nonce_group = 2;
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest
-
optional uint64 nonce_group = 2;
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequestOrBuilder
-
optional uint64 nonce_group = 2;
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint64 nonce_group = 13 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional uint64 nonce_group = 13 [default = 0];
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional uint64 nonce_group = 13 [default = 0];
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional uint64 nonce_group = 4;
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
optional uint64 nonce_group = 4;
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
-
optional uint64 nonce_group = 4;
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint64 nonceGroup = 9;
- hasNonceGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
optional uint64 nonceGroup = 9;
- hasNonceGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
optional uint64 nonceGroup = 9;
- hasNullColumnInQuery() - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
- hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 number_of_requests = 1;
- hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint64 number_of_requests = 1;
- hasNumberOfRequests() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint64 number_of_requests = 1;
- hasNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- hasNumberOfRows() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional uint32 number_of_rows = 4;
- hasNumberOfRows() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional uint32 number_of_rows = 4;
- hasNumberOfRows() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional uint32 number_of_rows = 4;
- hasNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 num_data_index_levels = 8;
- hasNumDataIndexLevels() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint32 num_data_index_levels = 8;
- hasNumDataIndexLevels() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint32 num_data_index_levels = 8;
- hasOccurrences() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- hasOccurrences() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- hasOccurrences() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- hasOffline() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bool offline = 5;
- hasOffline() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
optional bool offline = 5;
- hasOffline() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
optional bool offline = 5;
- hasOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
optional int32 offset = 2;
- hasOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter
-
optional int32 offset = 2;
- hasOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilterOrBuilder
-
optional int32 offset = 2;
- hasOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
required bool on = 1;
- hasOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
required bool on = 1;
- hasOn() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequestOrBuilder
-
required bool on = 1;
- hasOpenForDistributedLogReplay() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
optional bool openForDistributedLogReplay = 4;
- hasOpenForDistributedLogReplay() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
optional bool openForDistributedLogReplay = 4;
- hasOpenForDistributedLogReplay() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
-
optional bool openForDistributedLogReplay = 4;
- hasOpenSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
optional uint64 open_seq_num = 3;
- hasOpenSeqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
optional uint64 open_seq_num = 3;
- hasOpenSeqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransitionOrBuilder
-
optional uint64 open_seq_num = 3;
- hasOperator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
required .FilterList.Operator operator = 1;
- hasOperator() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList
-
required .FilterList.Operator operator = 1;
- hasOperator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterListOrBuilder
-
required .FilterList.Operator operator = 1;
- hasOrdinal() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
optional uint32 ordinal = 2;
- hasOrdinal() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel
-
optional uint32 ordinal = 2;
- hasOrdinal() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelOrBuilder
-
optional uint32 ordinal = 2;
- hasOrigSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint64 orig_sequence_number = 11;
- hasOrigSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
optional uint64 orig_sequence_number = 11;
- hasOrigSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
optional uint64 orig_sequence_number = 11;
- hasOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string osVersion = 3;
- hasOsVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string osVersion = 3;
- hasOsVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string osVersion = 3;
- hasOwner() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- hasOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional string owner = 6;
- hasOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
optional string owner = 6;
- hasOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
optional string owner = 6;
- hasOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional string owner = 5;
- hasOwner() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional string owner = 5;
- hasOwner() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional string owner = 5;
- hasPageSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
-
required int64 page_size = 1;
- hasPageSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter
-
required int64 page_size = 1;
- hasPageSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilterOrBuilder
-
required int64 page_size = 1;
- hasParent() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- hasParentId() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- hasParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint64 parent_id = 2;
- hasParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional uint64 parent_id = 2;
- hasParentId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional uint64 parent_id = 2;
- hasParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
optional int64 parent_id = 2;
- hasParentId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
optional int64 parent_id = 2;
- hasParentId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfoOrBuilder
-
optional int64 parent_id = 2;
- hasPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional bool partial = 5 [default = false];
- hasPartial() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
optional bool partial = 5 [default = false];
- hasPartial() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
optional bool partial = 5 [default = false];
- hasPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
optional bytes password = 2;
- hasPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
optional bytes password = 2;
- hasPassword() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
-
optional bytes password = 2;
- hasPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional bytes password = 2;
- hasPassword() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
optional bytes password = 2;
- hasPassword() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
-
optional bytes password = 2;
- hasPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
required string path = 2;
- hasPath() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath
-
required string path = 2;
- hasPath() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPathOrBuilder
-
required string path = 2;
- hasPattern() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required string pattern = 1;
- hasPattern() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
required string pattern = 1;
- hasPattern() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
-
required string pattern = 1;
- hasPatternFlags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required int32 pattern_flags = 2;
- hasPatternFlags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
required int32 pattern_flags = 2;
- hasPatternFlags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparatorOrBuilder
-
required int32 pattern_flags = 2;
- hasPayload() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
optional bytes payload = 5;
- hasPayload() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
optional bytes payload = 5;
- hasPayload() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
-
optional bytes payload = 5;
- hasPeerID() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required string peerID = 1;
- hasPeerID() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
required string peerID = 1;
- hasPeerID() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
-
required string peerID = 1;
- hasPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
required .Permission permission = 3;
- hasPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
required .Permission permission = 3;
- hasPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionOrBuilder
-
required .Permission permission = 3;
- hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
optional uint32 port = 2;
- hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
optional uint32 port = 2;
- hasPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
-
optional uint32 port = 2;
- hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
required uint32 port = 1;
- hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
required uint32 port = 1;
- hasPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
-
required uint32 port = 1;
- hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional int32 port = 4;
- hasPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional int32 port = 4;
- hasPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional int32 port = 4;
- hasPosition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
-
required int64 position = 1;
- hasPosition() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition
-
required int64 position = 1;
- hasPosition() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPositionOrBuilder
-
required int64 position = 1;
- hasPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
-
required bytes prefix = 1;
- hasPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter
-
required bytes prefix = 1;
- hasPrefix() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilterOrBuilder
-
required bytes prefix = 1;
- hasPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
-
optional bytes prefix = 1;
- hasPrefix() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter
-
optional bytes prefix = 1;
- hasPrefix() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilterOrBuilder
-
optional bytes prefix = 1;
- hasPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
required bool preserve_splits = 2;
- hasPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
required bool preserve_splits = 2;
- hasPreserveSplits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
required bool preserve_splits = 2;
- hasPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
optional bool preserveSplits = 2 [default = false];
- hasPreserveSplits() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
optional bool preserveSplits = 2 [default = false];
- hasPreserveSplits() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequestOrBuilder
-
optional bool preserveSplits = 2 [default = false];
- hasPrevBalanceValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
-
optional bool prev_balance_value = 1;
- hasPrevBalanceValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse
-
optional bool prev_balance_value = 1;
- hasPrevBalanceValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponseOrBuilder
-
optional bool prev_balance_value = 1;
- hasPreviousFanNodes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- hasPrevValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
-
optional bool prev_value = 1;
- hasPrevValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse
-
optional bool prev_value = 1;
- hasPrevValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponseOrBuilder
-
optional bool prev_value = 1;
- hasPriority() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- hasPriority() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional uint32 priority = 6;
- hasPriority() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional uint32 priority = 6;
- hasPriority() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional uint32 priority = 6;
- hasProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
required .ProcedureDescription procedure = 1;
- hasProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest
-
required .ProcedureDescription procedure = 1;
- hasProcedure() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequestOrBuilder
-
required .ProcedureDescription procedure = 1;
- hasProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
optional .ProcedureDescription procedure = 1;
- hasProcedure() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest
-
optional .ProcedureDescription procedure = 1;
- hasProcedure() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequestOrBuilder
-
optional .ProcedureDescription procedure = 1;
- hasProcedureSupport() - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- hasProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
optional bool processed = 2;
- hasProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse
-
optional bool processed = 2;
- hasProcessed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponseOrBuilder
-
optional bool processed = 2;
- hasProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
optional bool processed = 2;
- hasProcessed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
optional bool processed = 2;
- hasProcessed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponseOrBuilder
-
optional bool processed = 2;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
required uint64 proc_id = 1;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest
-
required uint64 proc_id = 1;
- hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequestOrBuilder
-
required uint64 proc_id = 1;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
-
optional uint64 proc_id = 1;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse
-
optional uint64 proc_id = 1;
- hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponseOrBuilder
-
optional uint64 proc_id = 1;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
-
optional uint64 proc_id = 1;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse
-
optional uint64 proc_id = 1;
- hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponseOrBuilder
-
optional uint64 proc_id = 1;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
-
optional uint64 proc_id = 1;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse
-
optional uint64 proc_id = 1;
- hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponseOrBuilder
-
optional uint64 proc_id = 1;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
-
optional uint64 proc_id = 1;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse
-
optional uint64 proc_id = 1;
- hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponseOrBuilder
-
optional uint64 proc_id = 1;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
-
required uint64 proc_id = 1;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest
-
required uint64 proc_id = 1;
- hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequestOrBuilder
-
required uint64 proc_id = 1;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required uint64 proc_id = 3;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
required uint64 proc_id = 3;
- hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
required uint64 proc_id = 3;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
optional uint64 proc_id = 3;
- hasProcId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
optional uint64 proc_id = 3;
- hasProcId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntryOrBuilder
-
optional uint64 proc_id = 3;
- hasPurpose() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional string purpose = 5;
- hasPurpose() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional string purpose = 5;
- hasPurpose() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional string purpose = 5;
- hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional bytes qualifier = 3;
- hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
optional bytes qualifier = 3;
- hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
-
optional bytes qualifier = 3;
- hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes qualifier = 3;
- hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional bytes qualifier = 3;
- hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional bytes qualifier = 3;
- hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
required bytes qualifier = 3;
- hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
required bytes qualifier = 3;
- hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
required bytes qualifier = 3;
- hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required bytes qualifier = 3;
- hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
required bytes qualifier = 3;
- hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
-
required bytes qualifier = 3;
- hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional bytes qualifier = 1;
- hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
optional bytes qualifier = 1;
- hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
-
optional bytes qualifier = 1;
- hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
required bytes qualifier = 2;
- hasQualifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName
-
required bytes qualifier = 2;
- hasQualifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableNameOrBuilder
-
required bytes qualifier = 2;
- hasQualifier() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- hasRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
required .Reference.Range range = 2;
- hasRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
required .Reference.Range range = 2;
- hasRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.ReferenceOrBuilder
-
required .Reference.Range range = 2;
- hasReadNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_num = 5;
- hasReadNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota read_num = 5;
- hasReadNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota read_num = 5;
- hasReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional bool readOnly = 5;
- hasReadOnly() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
optional bool readOnly = 5;
- hasReadOnly() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchemaOrBuilder
-
optional bool readOnly = 5;
- hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 read_requests_count = 8;
- hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint64 read_requests_count = 8;
- hasReadRequestsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint64 read_requests_count = 8;
- hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 readRequestsCount = 7;
- hasReadRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int64 readRequestsCount = 7;
- hasReadRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int64 readRequestsCount = 7;
- hasReadSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_size = 6;
- hasReadSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota read_size = 6;
- hasReadSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota read_size = 6;
- hasRealUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
optional string real_user = 2;
- hasRealUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation
-
optional string real_user = 2;
- hasRealUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformationOrBuilder
-
optional string real_user = 2;
- hasReason() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
required string reason = 1;
- hasReason() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest
-
required string reason = 1;
- hasReason() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequestOrBuilder
-
required string reason = 1;
- hasReference() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
optional .Reference reference = 2;
- hasReference() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile
-
optional .Reference reference = 2;
- hasReference() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFileOrBuilder
-
optional .Reference reference = 2;
- hasReferences() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- hasReferences(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Returns true if the specified family has reference files
- hasReferences(HTableDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Check whether region has Reference file
- hasReferences() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- hasReferences() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- hasReferences(Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.regionserver.StoreUtils
-
Determines whether any files in the collection are references.
- hasRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional string regex = 2;
- hasRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest
-
optional string regex = 2;
- hasRegex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequestOrBuilder
-
optional string regex = 2;
- hasRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional string regex = 1;
- hasRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest
-
optional string regex = 1;
- hasRegex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequestOrBuilder
-
optional string regex = 1;
- hasRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
optional string regex = 1;
- hasRegex() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest
-
optional string regex = 1;
- hasRegex() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequestOrBuilder
-
optional string regex = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
required .RegionInfo region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
required .RegionInfo region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
-
required .RegionInfo region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
required .RegionInfo region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo
-
required .RegionInfo region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfoOrBuilder
-
required .RegionInfo region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .RegionInfo region = 4;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
optional .RegionInfo region = 4;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplitOrBuilder
-
optional .RegionInfo region = 4;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest
-
required .RegionSpecifier region = 1;
- hasRegion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequestOrBuilder
-
required .RegionSpecifier region = 1;
- hasRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- hasRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
required .RegionSpecifier region_a = 1;
- hasRegionA() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
-
required .RegionSpecifier region_a = 1;
- hasRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- hasRegionA() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
required .RegionSpecifier region_a = 1;
- hasRegionA() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequestOrBuilder
-
required .RegionSpecifier region_a = 1;
- hasRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- hasRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest
-
required .RegionSpecifier region_b = 2;
- hasRegionB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequestOrBuilder
-
required .RegionSpecifier region_b = 2;
- hasRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- hasRegionB() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest
-
required .RegionSpecifier region_b = 2;
- hasRegionB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequestOrBuilder
-
required .RegionSpecifier region_b = 2;
- hasRegionId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
required uint64 region_id = 1;
- hasRegionId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
required uint64 region_id = 1;
- hasRegionId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
required uint64 region_id = 1;
- hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
required .RegionInfo region_info = 1;
- hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse
-
required .RegionInfo region_info = 1;
- hasRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponseOrBuilder
-
required .RegionInfo region_info = 1;
- hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
required .RegionInfo regionInfo = 1;
- hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest
-
required .RegionInfo regionInfo = 1;
- hasRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequestOrBuilder
-
required .RegionInfo regionInfo = 1;
- hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
required .RegionInfo region_info = 1;
- hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
required .RegionInfo region_info = 1;
- hasRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
-
required .RegionInfo region_info = 1;
- hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
required .RegionInfo region_info = 2;
- hasRegionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
required .RegionInfo region_info = 2;
- hasRegionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifestOrBuilder
-
required .RegionInfo region_info = 2;
- hasRegionMemstoreReplication() - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
-
required bytes region_name = 1;
- hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest
-
required bytes region_name = 1;
- hasRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequestOrBuilder
-
required bytes region_name = 1;
- hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
optional bytes region_name = 7;
- hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
optional bytes region_name = 7;
- hasRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
optional bytes region_name = 7;
- hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
optional bytes region_name = 6;
- hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
optional bytes region_name = 6;
- hasRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
optional bytes region_name = 6;
- hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional bytes region_name = 7;
- hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
optional bytes region_name = 7;
- hasRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
optional bytes region_name = 7;
- hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required bytes region_name = 2;
- hasRegionName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
required bytes region_name = 2;
- hasRegionName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
-
required bytes region_name = 2;
- hasRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
optional int32 regions = 3;
- hasRegions() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
optional int32 regions = 3;
- hasRegions() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
optional int32 regions = 3;
- hasRegionSpecifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
required .RegionSpecifier region_specifier = 1;
- hasRegionSpecifier() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
required .RegionSpecifier region_specifier = 1;
- hasRegionSpecifier() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
required .RegionSpecifier region_specifier = 1;
- hasRegionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionState region_state = 2;
- hasRegionState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
required .RegionState region_state = 2;
- hasRegionState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
-
required .RegionState region_state = 2;
- hasRegionsToAdd() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- hasRegionsToRemove() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- hasRegionsToRestore() - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
-
- hasRemoveAll() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional bool remove_all = 5;
- hasRemoveAll() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional bool remove_all = 5;
- hasRemoveAll() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional bool remove_all = 5;
- hasRenew() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool renew = 10 [default = false];
- hasRenew() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional bool renew = 10 [default = false];
- hasRenew() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional bool renew = 10 [default = false];
- hasReplicaId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional int32 replica_id = 7 [default = 0];
- hasReplicaId() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
optional int32 replica_id = 7 [default = 0];
- hasReplicaId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
optional int32 replica_id = 7 [default = 0];
- hasReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
optional string replicationEndpointImpl = 2;
- hasReplicationEndpointImpl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
optional string replicationEndpointImpl = 2;
- hasReplicationEndpointImpl() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeerOrBuilder
-
optional string replicationEndpointImpl = 2;
- hasReplicationLag() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint64 replicationLag = 5;
- hasReplicationLag() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
required uint64 replicationLag = 5;
- hasReplicationLag() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
-
required uint64 replicationLag = 5;
- hasReplLoadSink() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional .ReplicationLoadSink replLoadSink = 11;
- hasReplLoadSink() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional .ReplicationLoadSink replLoadSink = 11;
- hasReplLoadSink() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional .ReplicationLoadSink replLoadSink = 11;
- hasReportEndTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 report_end_time = 8;
- hasReportEndTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint64 report_end_time = 8;
- hasReportEndTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint64 report_end_time = 8;
- hasReportStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 report_start_time = 7;
- hasReportStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint64 report_start_time = 7;
- hasReportStartTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint64 report_start_time = 7;
- hasReqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_num = 1;
- hasReqNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota req_num = 1;
- hasReqNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota req_num = 1;
- hasReqSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_size = 2;
- hasReqSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota req_size = 2;
- hasReqSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota req_size = 2;
- hasRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required bytes request = 4;
- hasRequest() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
required bytes request = 4;
- hasRequest() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
-
required bytes request = 4;
- hasRequestParam() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional bool request_param = 4;
- hasRequestParam() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional bool request_param = 4;
- hasRequestParam() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional bool request_param = 4;
- hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
optional int64 requests = 4;
- hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
optional int64 requests = 4;
- hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int64 requests = 3;
- hasRequests() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
optional int64 requests = 3;
- hasRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
optional int64 requests = 3;
- hasRequests() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatusOrBuilder
-
optional int64 requests = 4;
- hasResponse() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
-
optional uint32 response = 1;
- hasResponse() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse
-
optional uint32 response = 1;
- hasResponse() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponseOrBuilder
-
optional uint32 response = 1;
- hasRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string restVersion = 1;
- hasRestVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string restVersion = 1;
- hasRestVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string restVersion = 1;
- hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
optional .Result result = 1;
- hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse
-
optional .Result result = 1;
- hasResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponseOrBuilder
-
optional .Result result = 1;
- hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
optional .Result result = 1;
- hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse
-
optional .Result result = 1;
- hasResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponseOrBuilder
-
optional .Result result = 1;
- hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .Result result = 2;
- hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional .Result result = 2;
- hasResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional .Result result = 2;
- hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional bytes result = 4;
- hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
optional bytes result = 4;
- hasResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
-
optional bytes result = 4;
- hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional bytes result = 11;
- hasResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional bytes result = 11;
- hasResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional bytes result = 11;
- hasResultData() - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- hasReturnData() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
optional bytes return_data = 2;
- hasReturnData() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse
-
optional bytes return_data = 2;
- hasReturnData() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponseOrBuilder
-
optional bytes return_data = 2;
- hasReversed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool reversed = 15 [default = false];
- hasReversed() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bool reversed = 15 [default = false];
- hasReversed() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bool reversed = 15 [default = false];
- hasRevision() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string revision = 3;
- hasRevision() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string revision = 3;
- hasRevision() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string revision = 3;
- hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 root_index_size_KB = 12;
- hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 root_index_size_KB = 12;
- hasRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 root_index_size_KB = 12;
- hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 rootIndexSizeKB = 9;
- hasRootIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 rootIndexSizeKB = 9;
- hasRootIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 rootIndexSizeKB = 9;
- hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional bytes row = 1;
- hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
required bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
required bytes row = 1;
- hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
required bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition
-
required bytes row = 1;
- hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ConditionOrBuilder
-
required bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
required bytes row = 1;
- hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
-
required bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
required bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
required bytes row = 1;
- hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
required bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional bytes row = 1;
- hasRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional bytes row = 1;
- hasRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
optional bytes row = 1;
- hasRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
optional bytes row = 1;
- hasRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required uint32 rowBatchSize = 4;
- hasRowBatchSize() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
required uint32 rowBatchSize = 4;
- hasRowBatchSize() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
-
required uint32 rowBatchSize = 4;
- hasRowProcessorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
required string row_processor_class_name = 1;
- hasRowProcessorClassName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
required string row_processor_class_name = 1;
- hasRowProcessorClassName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
-
required string row_processor_class_name = 1;
- hasRowProcessorInitializerMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional bytes row_processor_initializer_message = 3;
- hasRowProcessorInitializerMessage() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
optional bytes row_processor_initializer_message = 3;
- hasRowProcessorInitializerMessage() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
-
optional bytes row_processor_initializer_message = 3;
- hasRowProcessorInitializerMessageName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional string row_processor_initializer_message_name = 2;
- hasRowProcessorInitializerMessageName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest
-
optional string row_processor_initializer_message_name = 2;
- hasRowProcessorInitializerMessageName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequestOrBuilder
-
optional string row_processor_initializer_message_name = 2;
- hasRowProcessorResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
-
required bytes row_processor_result = 1;
- hasRowProcessorResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse
-
required bytes row_processor_result = 1;
- hasRowProcessorResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponseOrBuilder
-
required bytes row_processor_result = 1;
- hasRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
required uint64 rowsDeleted = 1;
- hasRowsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
required uint64 rowsDeleted = 1;
- hasRowsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
-
required uint64 rowsDeleted = 1;
- hasRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
optional uint32 rpc_version = 2;
- hasRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master
-
optional uint32 rpc_version = 2;
- hasRpcVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MasterOrBuilder
-
optional uint32 rpc_version = 2;
- hasRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
optional uint32 rpc_version = 2;
- hasRpcVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
optional uint32 rpc_version = 2;
- hasRpcVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServerOrBuilder
-
optional uint32 rpc_version = 2;
- hasScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required .Scan scan = 1;
- hasScan() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
required .Scan scan = 1;
- hasScan() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
-
required .Scan scan = 1;
- hasScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required .Scan scan = 2;
- hasScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
required .Scan scan = 2;
- hasScan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequestOrBuilder
-
required .Scan scan = 2;
- hasScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .Scan scan = 2;
- hasScan() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional .Scan scan = 2;
- hasScan() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional .Scan scan = 2;
- hasScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional uint64 scanner_id = 3;
- hasScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
optional uint64 scanner_id = 3;
- hasScannerId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequestOrBuilder
-
optional uint64 scanner_id = 3;
- hasScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional uint64 scanner_id = 2;
- hasScannerId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
optional uint64 scanner_id = 2;
- hasScannerId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
optional uint64 scanner_id = 2;
- hasScanResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
-
optional int32 scan_result = 1;
- hasScanResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
optional int32 scan_result = 1;
- hasScanResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponseOrBuilder
-
optional int32 scan_result = 1;
- hasScope() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
optional .QuotaScope scope = 4 [default = MACHINE];
- hasScope() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
optional .QuotaScope scope = 4 [default = MACHINE];
- hasScope() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuotaOrBuilder
-
optional .QuotaScope scope = 4 [default = MACHINE];
- hasScopeType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
required .ScopeType scope_type = 2;
- hasScopeType() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
required .ScopeType scope_type = 2;
- hasScopeType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScopeOrBuilder
-
required .ScopeType scope_type = 2;
- hasSecond() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
required bytes second = 2;
- hasSecond() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
required bytes second = 2;
- hasSecond() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPairOrBuilder
-
required bytes second = 2;
- hasSecondPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
optional bytes second_part = 2;
- hasSecondPart() - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
optional bytes second_part = 2;
- hasSecondPart() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponseOrBuilder
-
optional bytes second_part = 2;
- hasSelection() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
- hasSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
required uint64 sequence_id = 2;
- hasSequenceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
required uint64 sequence_id = 2;
- hasSequenceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceIdOrBuilder
-
required uint64 sequence_id = 2;
- hasSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
optional int64 sequence_number = 6;
- hasSequenceNumber() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
optional int64 sequence_number = 6;
- hasSequenceNumber() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
-
optional int64 sequence_number = 6;
- hasSerializedComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
optional bytes serialized_comparator = 2;
- hasSerializedComparator() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
optional bytes serialized_comparator = 2;
- hasSerializedComparator() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ComparatorOrBuilder
-
optional bytes serialized_comparator = 2;
- hasSerializedFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
optional bytes serialized_filter = 2;
- hasSerializedFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
optional bytes serialized_filter = 2;
- hasSerializedFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterOrBuilder
-
optional bytes serialized_filter = 2;
- hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerName server = 1;
- hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
required .ServerName server = 1;
- hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
-
required .ServerName server = 1;
- hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
required .ServerName server = 1;
- hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
required .ServerName server = 1;
- hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequestOrBuilder
-
required .ServerName server = 1;
- hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
required .ServerName server = 1;
- hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
required .ServerName server = 1;
- hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequestOrBuilder
-
required .ServerName server = 1;
- hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required .ServerName server = 1;
- hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
required .ServerName server = 1;
- hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequestOrBuilder
-
required .ServerName server = 1;
- hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional .ServerName server = 6;
- hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
optional .ServerName server = 6;
- hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
optional .ServerName server = 6;
- hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
required .ServerName server = 1;
- hasServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
required .ServerName server = 1;
- hasServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServerOrBuilder
-
required .ServerName server = 1;
- hasServerCurrentTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
required uint64 server_current_time = 3;
- hasServerCurrentTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
required uint64 server_current_time = 3;
- hasServerCurrentTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
-
required uint64 server_current_time = 3;
- hasServerInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
required .ServerInfo server_info = 1;
- hasServerInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
required .ServerInfo server_info = 1;
- hasServerInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponseOrBuilder
-
required .ServerInfo server_info = 1;
- hasServerLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerLoad server_load = 2;
- hasServerLoad() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
required .ServerLoad server_load = 2;
- hasServerLoad() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfoOrBuilder
-
required .ServerLoad server_load = 2;
- hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
required .ServerName server_name = 1;
- hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
required .ServerName server_name = 1;
- hasServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfoOrBuilder
-
required .ServerName server_name = 1;
- hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required .ServerName server_name = 4;
- hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
required .ServerName server_name = 4;
- hasServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransitionOrBuilder
-
required .ServerName server_name = 4;
- hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
required .ServerName server_name = 2;
- hasServerName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
required .ServerName server_name = 2;
- hasServerName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
-
required .ServerName server_name = 2;
- hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional uint64 serverStartCode = 5;
- hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
optional uint64 serverStartCode = 5;
- hasServerStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
-
optional uint64 serverStartCode = 5;
- hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
optional uint64 serverStartCode = 2;
- hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
optional uint64 serverStartCode = 2;
- hasServerStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequestOrBuilder
-
optional uint64 serverStartCode = 2;
- hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
required uint64 server_start_code = 2;
- hasServerStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
required uint64 server_start_code = 2;
- hasServerStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
-
required uint64 server_start_code = 2;
- hasServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string serverVersion = 4;
- hasServerVersion() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
optional string serverVersion = 4;
- hasServerVersion() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.VersionOrBuilder
-
optional string serverVersion = 4;
- hasService() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
optional bytes service = 3;
- hasService() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
optional bytes service = 3;
- hasService() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenOrBuilder
-
optional bytes service = 3;
- hasService() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional string service = 4;
- hasService() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
optional string service = 4;
- hasService() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationTokenOrBuilder
-
optional string service = 4;
- hasServiceCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .CoprocessorServiceCall service_call = 4;
- hasServiceCall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
optional .CoprocessorServiceCall service_call = 4;
- hasServiceCall() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ActionOrBuilder
-
optional .CoprocessorServiceCall service_call = 4;
- hasServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required string service_name = 2;
- hasServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
required string service_name = 2;
- hasServiceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCallOrBuilder
-
required string service_name = 2;
- hasServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string service_name = 2;
- hasServiceName() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional string service_name = 2;
- hasServiceName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional string service_name = 2;
- hasServiceResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .CoprocessorServiceResult service_result = 4;
- hasServiceResult() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
optional .CoprocessorServiceResult service_result = 4;
- hasServiceResult() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrExceptionOrBuilder
-
optional .CoprocessorServiceResult service_result = 4;
- hasShare() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
optional float share = 3;
- hasShare() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
optional float share = 3;
- hasShare() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuotaOrBuilder
-
optional float share = 3;
- hasSignature() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
required string signature = 1;
- hasSignature() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
required string signature = 1;
- hasSignature() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescriptionOrBuilder
-
required string signature = 1;
- hasSingleColumnValueFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- hasSingleColumnValueFilter() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- hasSingleColumnValueFilter() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilterOrBuilder
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- hasSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint32 sizeOfLogQueue = 3;
- hasSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
required uint32 sizeOfLogQueue = 3;
- hasSizeOfLogQueue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
-
required uint32 sizeOfLogQueue = 3;
- hasSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required bool skip_table_state_check = 3;
- hasSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
required bool skip_table_state_check = 3;
- hasSkipTableStateCheck() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateDataOrBuilder
-
required bool skip_table_state_check = 3;
- hasSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required bool skip_table_state_check = 3;
- hasSkipTableStateCheck() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
required bool skip_table_state_check = 3;
- hasSkipTableStateCheck() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateDataOrBuilder
-
required bool skip_table_state_check = 3;
- hasSmall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool small = 14;
- hasSmall() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bool small = 14;
- hasSmall() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bool small = 14;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
required .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequestOrBuilder
-
required .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
optional .ProcedureDescription snapshot = 2;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
optional .ProcedureDescription snapshot = 2;
- hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponseOrBuilder
-
optional .ProcedureDescription snapshot = 2;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
optional .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequestOrBuilder
-
optional .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
optional .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequestOrBuilder
-
optional .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
optional .SnapshotDescription snapshot = 2;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
optional .SnapshotDescription snapshot = 2;
- hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponseOrBuilder
-
optional .SnapshotDescription snapshot = 2;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
required .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequestOrBuilder
-
required .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
required .SnapshotDescription snapshot = 1;
- hasSnapshot() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequestOrBuilder
-
required .SnapshotDescription snapshot = 1;
- hasSoftLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
optional uint64 soft_limit = 2;
- hasSoftLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
optional uint64 soft_limit = 2;
- hasSoftLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuotaOrBuilder
-
optional uint64 soft_limit = 2;
- hasSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional string source = 1;
- hasSource() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
optional string source = 1;
- hasSource() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessageOrBuilder
-
optional string source = 1;
- hasSpec() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionSpecifier spec = 1;
- hasSpec() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
required .RegionSpecifier spec = 1;
- hasSpec() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransitionOrBuilder
-
required .RegionSpecifier spec = 1;
- hasSplit() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bool split = 6;
- hasSplit() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
optional bool split = 6;
- hasSplit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
optional bool split = 6;
- hasSplitkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
required bytes splitkey = 1;
- hasSplitkey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
required bytes splitkey = 1;
- hasSplitkey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.ReferenceOrBuilder
-
required bytes splitkey = 1;
- hasSplitPoint() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
optional bytes split_point = 2;
- hasSplitPoint() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
optional bytes split_point = 2;
- hasSplitPoint() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequestOrBuilder
-
optional bytes split_point = 2;
- hasSrcChecksum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string src_checksum = 6;
- hasSrcChecksum() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string src_checksum = 6;
- hasSrcChecksum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string src_checksum = 6;
- hasStackTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string stack_trace = 2;
- hasStackTrace() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
optional string stack_trace = 2;
- hasStackTrace() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponseOrBuilder
-
optional string stack_trace = 2;
- hasStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional bool stale = 4 [default = false];
- hasStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
optional bool stale = 4 [default = false];
- hasStale() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrBuilder
-
optional bool stale = 4 [default = false];
- hasStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool stale = 6;
- hasStale() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
optional bool stale = 6;
- hasStale() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
optional bool stale = 6;
- hasStamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
optional uint64 stamp = 3;
- hasStamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
optional uint64 stamp = 3;
- hasStamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
-
optional uint64 stamp = 3;
- hasStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
optional uint64 start_code = 3;
- hasStartCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
optional uint64 start_code = 3;
- hasStartCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerNameOrBuilder
-
optional uint64 start_code = 3;
- hasStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int64 startCode = 2;
- hasStartCode() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
optional int64 startCode = 2;
- hasStartCode() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder
-
optional int64 startCode = 2;
- hasStartDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
required string start_date = 1;
- hasStartDate() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
required string start_date = 1;
- hasStartDate() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUpOrBuilder
-
required string start_date = 1;
- hasStartId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
required uint64 start_id = 1;
- hasStartId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
required uint64 start_id = 1;
- hasStartId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNodeOrBuilder
-
required uint64 start_id = 1;
- hasStartKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bytes start_key = 3;
- hasStartKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
optional bytes start_key = 3;
- hasStartKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
optional bytes start_key = 3;
- hasStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional bytes startKey = 2;
- hasStartKey() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
optional bytes startKey = 2;
- hasStartKey() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.RegionOrBuilder
-
optional bytes startKey = 2;
- hasStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bytes start_row = 3;
- hasStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bytes start_row = 3;
- hasStartRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bytes start_row = 3;
- hasStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bytes start_row = 1;
- hasStartRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
optional bytes start_row = 1;
- hasStartRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRangeOrBuilder
-
optional bytes start_row = 1;
- hasStartRow() - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- hasStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional bytes startRow = 1;
- hasStartRow() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional bytes startRow = 1;
- hasStartRow() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional bytes startRow = 1;
- hasStartRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bool start_row_inclusive = 2;
- hasStartRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
optional bool start_row_inclusive = 2;
- hasStartRowInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRangeOrBuilder
-
optional bool start_row_inclusive = 2;
- hasStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional uint64 start_time = 2;
- hasStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
optional uint64 start_time = 2;
- hasStartTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
-
optional uint64 start_time = 2;
- hasStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required uint64 start_time = 4;
- hasStartTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
required uint64 start_time = 4;
- hasStartTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
required uint64 start_time = 4;
- hasStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int64 startTime = 5;
- hasStartTime() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
optional int64 startTime = 5;
- hasStartTime() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.ScannerOrBuilder
-
optional int64 startTime = 5;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
required .RegionState.State state = 2;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
required .RegionState.State state = 2;
- hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStateOrBuilder
-
required .RegionState.State state = 2;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
required .GetProcedureResultResponse.State state = 1;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
required .GetProcedureResultResponse.State state = 1;
- hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponseOrBuilder
-
required .GetProcedureResultResponse.State state = 1;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required .ProcedureState state = 6;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
required .ProcedureState state = 6;
- hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
required .ProcedureState state = 6;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
optional .RegionState.State state = 3;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
optional .RegionState.State state = 3;
- hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServerOrBuilder
-
optional .RegionState.State state = 3;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
-
required .ReplicationState.State state = 1;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
required .ReplicationState.State state = 1;
- hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationStateOrBuilder
-
required .ReplicationState.State state = 1;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
required .SplitLogTask.State state = 1;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
required .SplitLogTask.State state = 1;
- hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTaskOrBuilder
-
required .SplitLogTask.State state = 1;
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
-
required .Table.State state = 1 [default = ENABLED];
- hasState() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
required .Table.State state = 1 [default = ENABLED];
- hasState() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableOrBuilder
-
required .Table.State state = 1 [default = ENABLED];
- hasStateData() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional bytes state_data = 12;
- hasStateData() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional bytes state_data = 12;
- hasStateData() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional bytes state_data = 12;
- hasStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bytes stop_row = 4;
- hasStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional bytes stop_row = 4;
- hasStopRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional bytes stop_row = 4;
- hasStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bytes stop_row = 3;
- hasStopRow() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
optional bytes stop_row = 3;
- hasStopRow() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRangeOrBuilder
-
optional bytes stop_row = 3;
- hasStopRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bool stop_row_inclusive = 4;
- hasStopRowInclusive() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
optional bool stop_row_inclusive = 4;
- hasStopRowInclusive() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRangeOrBuilder
-
optional bool stop_row_inclusive = 4;
- hasStopRowKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
-
optional bytes stop_row_key = 1;
- hasStopRowKey() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
optional bytes stop_row_key = 1;
- hasStopRowKey() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilterOrBuilder
-
optional bytes stop_row_key = 1;
- hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 storefile_index_size_MB = 7;
- hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 storefile_index_size_MB = 7;
- hasStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 storefile_index_size_MB = 7;
- hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 storefileIndexSizeMB = 6;
- hasStorefileIndexSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 storefileIndexSizeMB = 6;
- hasStorefileIndexSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 storefileIndexSizeMB = 6;
- hasStorefiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 storefiles = 3;
- hasStorefiles() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 storefiles = 3;
- hasStorefiles() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 storefiles = 3;
- hasStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 storefiles = 3;
- hasStorefiles() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 storefiles = 3;
- hasStorefiles() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 storefiles = 3;
- hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 storefile_size_MB = 5;
- hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 storefile_size_MB = 5;
- hasStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 storefile_size_MB = 5;
- hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 storefileSizeMB = 4;
- hasStorefileSizeMB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 storefileSizeMB = 4;
- hasStorefileSizeMB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 storefileSizeMB = 4;
- hasStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required string store_home_dir = 6;
- hasStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
required string store_home_dir = 6;
- hasStoreHomeDir() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
required string store_home_dir = 6;
- hasStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
required string store_home_dir = 2;
- hasStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
required string store_home_dir = 2;
- hasStoreHomeDir() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptorOrBuilder
-
required string store_home_dir = 2;
- hasStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
required string store_home_dir = 2;
- hasStoreHomeDir() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
required string store_home_dir = 2;
- hasStoreHomeDir() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptorOrBuilder
-
required string store_home_dir = 2;
- hasStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional uint32 store_limit = 8;
- hasStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional uint32 store_limit = 8;
- hasStoreLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional uint32 store_limit = 8;
- hasStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 store_limit = 11;
- hasStoreLimit() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional uint32 store_limit = 11;
- hasStoreLimit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional uint32 store_limit = 11;
- hasStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional uint32 store_offset = 9;
- hasStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional uint32 store_offset = 9;
- hasStoreOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional uint32 store_offset = 9;
- hasStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 store_offset = 12;
- hasStoreOffset() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional uint32 store_offset = 12;
- hasStoreOffset() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional uint32 store_offset = 12;
- hasStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 stores = 2;
- hasStores() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 stores = 2;
- hasStores() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 stores = 2;
- hasStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 stores = 2;
- hasStores() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 stores = 2;
- hasStores() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 stores = 2;
- hasStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 store_uncompressed_size_MB = 4;
- hasStoreUncompressedSizeMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 store_uncompressed_size_MB = 4;
- hasStoreUncompressedSizeMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 store_uncompressed_size_MB = 4;
- hasSubstr() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
required string substr = 1;
- hasSubstr() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
required string substr = 1;
- hasSubstr() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparatorOrBuilder
-
required string substr = 1;
- hasSynchronous() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
optional bool synchronous = 2;
- hasSynchronous() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
optional bool synchronous = 2;
- hasSynchronous() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequestOrBuilder
-
optional bool synchronous = 2;
- hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional string table = 2;
- hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
optional string table = 2;
- hasTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
optional string table = 2;
- hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .TableSchema table = 3;
- hasTable() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit
-
optional .TableSchema table = 3;
- hasTable() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplitOrBuilder
-
optional .TableSchema table = 3;
- hasTable() - Method in class org.apache.hadoop.hbase.security.access.TablePermission
-
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
optional .TableName table_name = 2;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequestOrBuilder
-
optional .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
optional .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermissionOrBuilder
-
optional .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
required .TableName table_name = 2;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfoOrBuilder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
optional .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
optional .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchemaOrBuilder
-
optional .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
required .TableName table_name = 2;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
required .TableName table_name = 2;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
required .TableName table_name = 2;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
required .TableName table_name = 2;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateDataOrBuilder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
required .TableName table_name = 2;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateDataOrBuilder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
required .TableName table_name = 2;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
-
required .TableName table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableName table_name = 3;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
optional .TableName table_name = 3;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
optional .TableName table_name = 3;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest
-
required .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequestOrBuilder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest
-
required .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequestOrBuilder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest
-
required .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequestOrBuilder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest
-
required .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequestOrBuilder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest
-
required .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequestOrBuilder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest
-
required .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequestOrBuilder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest
-
required .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequestOrBuilder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest
-
required .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequestOrBuilder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
required .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequestOrBuilder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .TableName table_name = 4;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional .TableName table_name = 4;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional .TableName table_name = 4;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
required .TableName tableName = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest
-
required .TableName tableName = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequestOrBuilder
-
required .TableName tableName = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest
-
required .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequestOrBuilder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
required .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptorOrBuilder
-
required .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required bytes table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
required bytes table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptorOrBuilder
-
required bytes table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
required bytes table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
required bytes table_name = 2;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptorOrBuilder
-
required bytes table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
required bytes table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
required bytes table_name = 2;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptorOrBuilder
-
required bytes table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required bytes table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
required bytes table_name = 2;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
required bytes table_name = 2;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .TableName table_name = 1;
- hasTableName() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional .TableName table_name = 1;
- hasTableName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional .TableName table_name = 1;
- hasTablePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .TablePermission table_permission = 4;
- hasTablePermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
optional .TablePermission table_permission = 4;
- hasTablePermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
-
optional .TablePermission table_permission = 4;
- hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .TableSchema table_schema = 2;
- hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
required .TableSchema table_schema = 2;
- hasTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
-
required .TableSchema table_schema = 2;
- hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableSchema table_schema = 4;
- hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
optional .TableSchema table_schema = 4;
- hasTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
optional .TableSchema table_schema = 4;
- hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
required .TableSchema table_schema = 1;
- hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
required .TableSchema table_schema = 1;
- hasTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequestOrBuilder
-
required .TableSchema table_schema = 1;
- hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableSchema table_schema = 2;
- hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest
-
required .TableSchema table_schema = 2;
- hasTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequestOrBuilder
-
required .TableSchema table_schema = 2;
- hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
required .TableSchema table_schema = 1;
- hasTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest
-
required .TableSchema table_schema = 1;
- hasTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifestOrBuilder
-
required .TableSchema table_schema = 1;
- hasTagCompression - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- hasTagCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- hasTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes tags = 7;
- hasTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional bytes tags = 7;
- hasTags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional bytes tags = 7;
- hasTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional bytes tags = 7;
- hasTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
optional bytes tags = 7;
- hasTags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
optional bytes tags = 7;
- hasTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional bytes tags = 5;
- hasTags() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
optional bytes tags = 5;
- hasTags() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
-
optional bytes tags = 5;
- HasThread - Class in org.apache.hadoop.hbase.util
-
Abstract class which contains a Thread and delegates the common Thread
methods to that instance.
- HasThread() - Constructor for class org.apache.hadoop.hbase.util.HasThread
-
- HasThread(String) - Constructor for class org.apache.hadoop.hbase.util.HasThread
-
- hasThreadId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional int64 thread_id = 3;
- hasThreadId() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock
-
optional int64 thread_id = 3;
- hasThreadId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLockOrBuilder
-
optional int64 thread_id = 3;
- hasThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .ThrottleRequest throttle = 7;
- hasThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional .ThrottleRequest throttle = 7;
- hasThrottle() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional .ThrottleRequest throttle = 7;
- hasThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
optional .Throttle throttle = 2;
- hasThrottle() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas
-
optional .Throttle throttle = 2;
- hasThrottle() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.QuotasOrBuilder
-
optional .Throttle throttle = 2;
- hasTimedQuota() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
optional .TimedQuota timed_quota = 2;
- hasTimedQuota() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
optional .TimedQuota timed_quota = 2;
- hasTimedQuota() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequestOrBuilder
-
optional .TimedQuota timed_quota = 2;
- hasTimeout() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- hasTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint32 timeout = 9;
- hasTimeout() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
optional uint32 timeout = 9;
- hasTimeout() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureOrBuilder
-
optional uint32 timeout = 9;
- hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .TimeRange time_range = 5;
- hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
optional .TimeRange time_range = 5;
- hasTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetOrBuilder
-
optional .TimeRange time_range = 5;
- hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .TimeRange time_range = 7;
- hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional .TimeRange time_range = 7;
- hasTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional .TimeRange time_range = 7;
- hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .TimeRange time_range = 6;
- hasTimeRange() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
optional .TimeRange time_range = 6;
- hasTimeRange() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanOrBuilder
-
optional .TimeRange time_range = 6;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
optional uint64 timestamp = 3;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
optional uint64 timestamp = 3;
- hasTimestamp() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequestOrBuilder
-
optional uint64 timestamp = 3;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional uint64 timestamp = 4;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional uint64 timestamp = 4;
- hasTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional uint64 timestamp = 4;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional uint64 timestamp = 4;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
optional uint64 timestamp = 4;
- hasTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
optional uint64 timestamp = 4;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional uint64 timestamp = 4;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional uint64 timestamp = 3;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
optional uint64 timestamp = 3;
- hasTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
-
optional uint64 timestamp = 3;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
optional uint64 timestamp = 4;
- hasTimestamp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProtoOrBuilder
-
optional uint64 timestamp = 4;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional int64 timestamp = 3;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
optional int64 timestamp = 3;
- hasTimestamp() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.CellOrBuilder
-
optional int64 timestamp = 3;
- hasTimestamp() - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- hasTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint64 timeStampOfLastShippedOp = 4;
- hasTimeStampOfLastShippedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
required uint64 timeStampOfLastShippedOp = 4;
- hasTimeStampOfLastShippedOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSourceOrBuilder
-
required uint64 timeStampOfLastShippedOp = 4;
- hasTimeStampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
required uint64 timeStampsOfLastAppliedOp = 2;
- hasTimeStampsOfLastAppliedOp() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
required uint64 timeStampsOfLastAppliedOp = 2;
- hasTimeStampsOfLastAppliedOp() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSinkOrBuilder
-
required uint64 timeStampsOfLastAppliedOp = 2;
- hasTimeUnit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
required .TimeUnit time_unit = 1;
- hasTimeUnit() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
required .TimeUnit time_unit = 1;
- hasTimeUnit() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuotaOrBuilder
-
required .TimeUnit time_unit = 1;
- hasTo() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
optional uint64 to = 2;
- hasTo() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange
-
optional uint64 to = 2;
- hasTo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRangeOrBuilder
-
optional uint64 to = 2;
- hasToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
optional .Token token = 1;
- hasToken() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse
-
optional .Token token = 1;
- hasToken() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponseOrBuilder
-
optional .Token token = 1;
- hasTooManyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- hasTooManyStoreFiles() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 total_compacting_KVs = 10;
- hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint64 total_compacting_KVs = 10;
- hasTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint64 total_compacting_KVs = 10;
- hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 totalCompactingKVs = 12;
- hasTotalCompactingKVs() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int64 totalCompactingKVs = 12;
- hasTotalCompactingKVs() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int64 totalCompactingKVs = 12;
- hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 total_number_of_requests = 2;
- hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint64 total_number_of_requests = 2;
- hasTotalNumberOfRequests() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint64 total_number_of_requests = 2;
- hasTotalNumberOfRequests() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- hasTotalRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
optional uint32 total_regions = 2;
- hasTotalRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
optional uint32 total_regions = 2;
- hasTotalRegions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponseOrBuilder
-
optional uint32 total_regions = 2;
- hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 total_static_bloom_size_KB = 14;
- hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 total_static_bloom_size_KB = 14;
- hasTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 total_static_bloom_size_KB = 14;
- hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 totalStaticBloomSizeKB = 11;
- hasTotalStaticBloomSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 totalStaticBloomSizeKB = 11;
- hasTotalStaticBloomSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 totalStaticBloomSizeKB = 11;
- hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 total_static_index_size_KB = 13;
- hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint32 total_static_index_size_KB = 13;
- hasTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint32 total_static_index_size_KB = 13;
- hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 totalStaticIndexSizeKB = 10;
- hasTotalStaticIndexSizeKB() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int32 totalStaticIndexSizeKB = 10;
- hasTotalStaticIndexSizeKB() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int32 totalStaticIndexSizeKB = 10;
- hasTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 total_uncompressed_bytes = 4;
- hasTotalUncompressedBytes() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 total_uncompressed_bytes = 4;
- hasTotalUncompressedBytes() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 total_uncompressed_bytes = 4;
- hasTraceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
optional int64 trace_id = 1;
- hasTraceId() - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo
-
optional int64 trace_id = 1;
- hasTraceId() - Method in interface org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfoOrBuilder
-
optional int64 trace_id = 1;
- hasTraceInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .RPCTInfo trace_info = 2;
- hasTraceInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader
-
optional .RPCTInfo trace_info = 2;
- hasTraceInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeaderOrBuilder
-
optional .RPCTInfo trace_info = 2;
- hasTrackerPos() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
required uint64 tracker_pos = 2;
- hasTrackerPos() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
required uint64 tracker_pos = 2;
- hasTrackerPos() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailerOrBuilder
-
required uint64 tracker_pos = 2;
- hasTransitionCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
required .RegionStateTransition.TransitionCode transition_code = 1;
- hasTransitionCode() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition
-
required .RegionStateTransition.TransitionCode transition_code = 1;
- hasTransitionCode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransitionOrBuilder
-
required .RegionStateTransition.TransitionCode transition_code = 1;
- hasTransitionInZK() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional bool transition_in_ZK = 3 [default = true];
- hasTransitionInZK() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
optional bool transition_in_ZK = 3 [default = true];
- hasTransitionInZK() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
-
optional bool transition_in_ZK = 3 [default = true];
- hasTtl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional uint32 ttl = 4;
- hasTtl() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
optional uint32 ttl = 4;
- hasTtl() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponseOrBuilder
-
optional uint32 ttl = 4;
- hasTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional int32 ttl = 3;
- hasTtl() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
optional int32 ttl = 3;
- hasTtl() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchemaOrBuilder
-
optional int32 ttl = 3;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional .Permission.Type type = 1;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest
-
optional .Permission.Type type = 1;
- hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequestOrBuilder
-
optional .Permission.Type type = 1;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
required .Permission.Type type = 1;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission
-
required .Permission.Type type = 1;
- hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.PermissionOrBuilder
-
required .Permission.Type type = 1;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
required .RegionSpecifier.RegionSpecifierType type = 1;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
required .RegionSpecifier.RegionSpecifierType type = 1;
- hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifierOrBuilder
-
required .RegionSpecifier.RegionSpecifierType type = 1;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional .SnapshotDescription.Type type = 4 [default = FLUSH];
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
optional .SnapshotDescription.Type type = 4 [default = FLUSH];
- hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
optional .SnapshotDescription.Type type = 4 [default = FLUSH];
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
required .ProcedureWALEntry.Type type = 1;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry
-
required .ProcedureWALEntry.Type type = 1;
- hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntryOrBuilder
-
required .ProcedureWALEntry.Type type = 1;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint32 type = 2;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
required uint32 type = 2;
- hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeaderOrBuilder
-
required uint32 type = 2;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
optional .ThrottleType type = 1;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest
-
optional .ThrottleType type = 1;
- hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequestOrBuilder
-
optional .ThrottleType type = 1;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
required .SnapshotFileInfo.Type type = 1;
- hasType() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
required .SnapshotFileInfo.Type type = 1;
- hasType() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
-
required .SnapshotFileInfo.Type type = 1;
- hasUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 uncompressed_data_index_size = 3;
- hasUncompressedDataIndexSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
optional uint64 uncompressed_data_index_size = 3;
- hasUncompressedDataIndexSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProtoOrBuilder
-
optional uint64 uncompressed_data_index_size = 3;
- hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
optional .TableSchema unmodified_table_schema = 4;
- hasUnmodifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
-
optional .TableSchema unmodified_table_schema = 4;
- hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
optional .TableSchema unmodified_table_schema = 4;
- hasUnmodifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
-
optional .TableSchema unmodified_table_schema = 4;
- hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
optional .TableSchema unmodified_table_schema = 4;
- hasUnmodifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
-
optional .TableSchema unmodified_table_schema = 4;
- hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
optional .TableSchema unmodified_table_schema = 2;
- hasUnmodifiedTableSchema() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
optional .TableSchema unmodified_table_schema = 2;
- hasUnmodifiedTableSchema() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
-
optional .TableSchema unmodified_table_schema = 2;
- hasUrl() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string url = 2;
- hasUrl() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string url = 2;
- hasUrl() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string url = 2;
- hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint32 used_heap_MB = 3;
- hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad
-
optional uint32 used_heap_MB = 3;
- hasUsedHeapMB() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoadOrBuilder
-
optional uint32 used_heap_MB = 3;
- hasUsedHeapMB() - Method in class org.apache.hadoop.hbase.ServerLoad
-
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
required bytes user = 1;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission
-
required bytes user = 1;
- hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermissionOrBuilder
-
required bytes user = 1;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
required bytes user = 1;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions
-
required bytes user = 1;
- hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissionsOrBuilder
-
required bytes user = 1;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string user = 4;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string user = 4;
- hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string user = 4;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
-
required bytes user = 1;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest
-
required bytes user = 1;
- hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequestOrBuilder
-
required bytes user = 1;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
required bytes user = 1;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
required bytes user = 1;
- hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponseOrBuilder
-
required bytes user = 1;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
required bytes user = 1;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
required bytes user = 1;
- hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequestOrBuilder
-
required bytes user = 1;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
required bytes user = 1;
- hasUser() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
required bytes user = 1;
- hasUser() - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizationsOrBuilder
-
required bytes user = 1;
- hasUserGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string user_group = 2;
- hasUserGroup() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional string user_group = 2;
- hasUserGroup() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional string user_group = 2;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateDataOrBuilder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateDataOrBuilder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateDataOrBuilder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateDataOrBuilder
-
required .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .UserInformation user_info = 1;
- hasUserInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional .UserInformation user_info = 1;
- hasUserInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional .UserInformation user_info = 1;
- hasUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
required bytes username = 2;
- hasUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
required bytes username = 2;
- hasUsername() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifierOrBuilder
-
required bytes username = 2;
- hasUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
optional string username = 1;
- hasUsername() - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
optional string username = 1;
- hasUsername() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponseOrBuilder
-
optional string username = 1;
- hasUserName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string user_name = 1;
- hasUserName() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest
-
optional string user_name = 1;
- hasUserName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequestOrBuilder
-
optional string user_name = 1;
- hasUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
required .UserPermission user_permission = 1;
- hasUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest
-
required .UserPermission user_permission = 1;
- hasUserPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequestOrBuilder
-
required .UserPermission user_permission = 1;
- hasUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
required .UserPermission user_permission = 1;
- hasUserPermission() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest
-
required .UserPermission user_permission = 1;
- hasUserPermission() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequestOrBuilder
-
required .UserPermission user_permission = 1;
- hasUserTimestamp() - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- hasUseThisHostnameInstead() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
optional string use_this_hostname_instead = 4;
- hasUseThisHostnameInstead() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
optional string use_this_hostname_instead = 4;
- hasUseThisHostnameInstead() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequestOrBuilder
-
optional string use_this_hostname_instead = 4;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes value = 6;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell
-
optional bytes value = 6;
- hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellOrBuilder
-
optional bytes value = 6;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional bytes value = 6;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
-
optional bytes value = 6;
- hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValueOrBuilder
-
optional bytes value = 6;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .NameBytesPair value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse
-
required .NameBytesPair value = 2;
- hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponseOrBuilder
-
required .NameBytesPair value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
optional .NameBytesPair value = 1;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult
-
optional .NameBytesPair value = 1;
- hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResultOrBuilder
-
optional .NameBytesPair value = 1;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional bytes value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
optional bytes value = 2;
- hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValueOrBuilder
-
optional bytes value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
-
optional bytes value = 1;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable
-
optional bytes value = 1;
- hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparableOrBuilder
-
optional bytes value = 1;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
optional bytes value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair
-
optional bytes value = 2;
- hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPairOrBuilder
-
optional bytes value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
optional int64 value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair
-
optional int64 value = 2;
- hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64PairOrBuilder
-
optional int64 value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
required string value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair
-
required string value = 2;
- hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPairOrBuilder
-
required string value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
required bytes value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier
-
required bytes value = 2;
- hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifierOrBuilder
-
required bytes value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
-
required bool value = 1;
- hasValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse
-
required bool value = 1;
- hasValue() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponseOrBuilder
-
required bool value = 1;
- hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
required string value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute
-
required string value = 2;
- hasValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.AttributeOrBuilder
-
required string value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
required string value = 2;
- hasValue() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute
-
required string value = 2;
- hasValue() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.AttributeOrBuilder
-
required string value = 2;
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
required string version = 1;
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent
-
required string version = 1;
- hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContentOrBuilder
-
required string version = 1;
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional int32 version = 5;
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription
-
optional int32 version = 5;
- hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescriptionOrBuilder
-
optional int32 version = 5;
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint32 version = 1;
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader
-
required uint32 version = 1;
- hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeaderOrBuilder
-
required uint32 version = 1;
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
required uint32 version = 1;
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer
-
required uint32 version = 1;
- hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailerOrBuilder
-
required uint32 version = 1;
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string version = 1;
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
required string version = 1;
- hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfoOrBuilder
-
required string version = 1;
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
optional int32 version = 1;
- hasVersion() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest
-
optional int32 version = 1;
- hasVersion() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifestOrBuilder
-
optional int32 version = 1;
- hasVersionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .VersionInfo version_info = 5;
- hasVersionInfo() - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
optional .VersionInfo version_info = 5;
- hasVersionInfo() - Method in interface org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeaderOrBuilder
-
optional .VersionInfo version_info = 5;
- hasVersionOfClosingNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional uint32 version_of_closing_node = 2;
- hasVersionOfClosingNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
optional uint32 version_of_closing_node = 2;
- hasVersionOfClosingNode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequestOrBuilder
-
optional uint32 version_of_closing_node = 2;
- hasVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
optional uint32 version_of_offline_node = 2;
- hasVersionOfOfflineNode() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo
-
optional uint32 version_of_offline_node = 2;
- hasVersionOfOfflineNode() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder
-
optional uint32 version_of_offline_node = 2;
- hasVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
optional uint64 versionsDeleted = 2;
- hasVersionsDeleted() - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse
-
optional uint64 versionsDeleted = 2;
- hasVersionsDeleted() - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponseOrBuilder
-
optional uint64 versionsDeleted = 2;
- hasWalName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string wal_name = 5;
- hasWalName() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
optional string wal_name = 5;
- hasWalName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
-
optional string wal_name = 5;
- hasWalServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string wal_server = 4;
- hasWalServer() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
optional string wal_server = 4;
- hasWalServer() - Method in interface org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfoOrBuilder
-
optional string wal_server = 4;
- hasWebuiPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
optional uint32 webui_port = 2;
- hasWebuiPort() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
optional uint32 webui_port = 2;
- hasWebuiPort() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfoOrBuilder
-
optional uint32 webui_port = 2;
- hasWriteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
optional bool write_flush_wal_marker = 3;
- hasWriteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest
-
optional bool write_flush_wal_marker = 3;
- hasWriteFlushWalMarker() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequestOrBuilder
-
optional bool write_flush_wal_marker = 3;
- hasWriteNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_num = 3;
- hasWriteNum() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota write_num = 3;
- hasWriteNum() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota write_num = 3;
- hasWriterClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional string writer_cls_name = 4;
- hasWriterClsName() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader
-
optional string writer_cls_name = 4;
- hasWriterClsName() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeaderOrBuilder
-
optional string writer_cls_name = 4;
- hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 write_requests_count = 9;
- hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
optional uint64 write_requests_count = 9;
- hasWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoadOrBuilder
-
optional uint64 write_requests_count = 9;
- hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 writeRequestsCount = 8;
- hasWriteRequestsCount() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
optional int64 writeRequestsCount = 8;
- hasWriteRequestsCount() - Method in interface org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder
-
optional int64 writeRequestsCount = 8;
- hasWriteSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_size = 4;
- hasWriteSize() - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle
-
optional .TimedQuota write_size = 4;
- hasWriteSize() - Method in interface org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleOrBuilder
-
optional .TimedQuota write_size = 4;
- hasWriteTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required uint64 write_time = 4;
- hasWriteTime() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
required uint64 write_time = 4;
- hasWriteTime() - Method in interface org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKeyOrBuilder
-
required uint64 write_time = 4;
- hasWroteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
optional bool wrote_flush_wal_marker = 3;
- hasWroteFlushWalMarker() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse
-
optional bool wrote_flush_wal_marker = 3;
- hasWroteFlushWalMarker() - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponseOrBuilder
-
optional bool wrote_flush_wal_marker = 3;
- hasYetToUpdateRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
optional uint32 yet_to_update_regions = 1;
- hasYetToUpdateRegions() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse
-
optional uint32 yet_to_update_regions = 1;
- hasYetToUpdateRegions() - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponseOrBuilder
-
optional uint32 yet_to_update_regions = 1;
- havingSystemAuth(byte[]) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
Deprecated.
- havingSystemAuth(User) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- havingSystemAuth(byte[]) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
- havingSystemAuth(User) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
System checks for user auth during admin operations.
- Hbase - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase
-
- Hbase.append_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.append_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
- Hbase.append_args(TAppend) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
- Hbase.append_args(Hbase.append_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
Performs a deep copy on other.
- Hbase.append_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.append_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.append_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- Hbase.append_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- Hbase.append_result(Hbase.append_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
Performs a deep copy on other.
- Hbase.append_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.AsyncClient - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- Hbase.AsyncClient.append_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.append_call(TAppend, AsyncMethodCallback<Hbase.AsyncClient.append_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.append_call
-
- Hbase.AsyncClient.atomicIncrement_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.atomicIncrement_call(ByteBuffer, ByteBuffer, ByteBuffer, long, AsyncMethodCallback<Hbase.AsyncClient.atomicIncrement_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.atomicIncrement_call
-
- Hbase.AsyncClient.checkAndPut_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.checkAndPut_call(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.checkAndPut_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.checkAndPut_call
-
- Hbase.AsyncClient.compact_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.compact_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.compact_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.compact_call
-
- Hbase.AsyncClient.createTable_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.createTable_call(ByteBuffer, List<ColumnDescriptor>, AsyncMethodCallback<Hbase.AsyncClient.createTable_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.createTable_call
-
- Hbase.AsyncClient.deleteAll_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.deleteAll_call(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAll_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAll_call
-
- Hbase.AsyncClient.deleteAllRow_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.deleteAllRow_call(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAllRow_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRow_call
-
- Hbase.AsyncClient.deleteAllRowTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.deleteAllRowTs_call(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAllRowTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRowTs_call
-
- Hbase.AsyncClient.deleteAllTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.deleteAllTs_call(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.deleteAllTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllTs_call
-
- Hbase.AsyncClient.deleteTable_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.deleteTable_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.deleteTable_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteTable_call
-
- Hbase.AsyncClient.disableTable_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.disableTable_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.disableTable_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.disableTable_call
-
- Hbase.AsyncClient.enableTable_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.enableTable_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.enableTable_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.enableTable_call
-
- Hbase.AsyncClient.Factory - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.Factory
-
- Hbase.AsyncClient.get_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.get_call(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.get_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.get_call
-
- Hbase.AsyncClient.getColumnDescriptors_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getColumnDescriptors_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getColumnDescriptors_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getColumnDescriptors_call
-
- Hbase.AsyncClient.getRegionInfo_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRegionInfo_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getRegionInfo_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRegionInfo_call
-
- Hbase.AsyncClient.getRow_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRow_call(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRow_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRow_call
-
- Hbase.AsyncClient.getRowOrBefore_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowOrBefore_call(ByteBuffer, ByteBuffer, ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getRowOrBefore_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowOrBefore_call
-
- Hbase.AsyncClient.getRows_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRows_call(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRows_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRows_call
-
- Hbase.AsyncClient.getRowsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowsTs_call(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsTs_call
-
- Hbase.AsyncClient.getRowsWithColumns_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowsWithColumns_call(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumns_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumns_call
-
- Hbase.AsyncClient.getRowsWithColumnsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowsWithColumnsTs_call(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowsWithColumnsTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowsWithColumnsTs_call
-
- Hbase.AsyncClient.getRowTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowTs_call(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowTs_call
-
- Hbase.AsyncClient.getRowWithColumns_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowWithColumns_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumns_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumns_call
-
- Hbase.AsyncClient.getRowWithColumnsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getRowWithColumnsTs_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getRowWithColumnsTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getRowWithColumnsTs_call
-
- Hbase.AsyncClient.getTableNames_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getTableNames_call(AsyncMethodCallback<Hbase.AsyncClient.getTableNames_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableNames_call
-
- Hbase.AsyncClient.getTableRegions_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getTableRegions_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.getTableRegions_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getTableRegions_call
-
- Hbase.AsyncClient.getVer_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getVer_call(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getVer_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVer_call
-
- Hbase.AsyncClient.getVerTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.getVerTs_call(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.getVerTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.getVerTs_call
-
- Hbase.AsyncClient.increment_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.increment_call(TIncrement, AsyncMethodCallback<Hbase.AsyncClient.increment_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.increment_call
-
- Hbase.AsyncClient.incrementRows_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.incrementRows_call(List<TIncrement>, AsyncMethodCallback<Hbase.AsyncClient.incrementRows_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.incrementRows_call
-
- Hbase.AsyncClient.isTableEnabled_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.isTableEnabled_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.isTableEnabled_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.isTableEnabled_call
-
- Hbase.AsyncClient.majorCompact_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.majorCompact_call(ByteBuffer, AsyncMethodCallback<Hbase.AsyncClient.majorCompact_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.majorCompact_call
-
- Hbase.AsyncClient.mutateRow_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.mutateRow_call(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.mutateRow_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRow_call
-
- Hbase.AsyncClient.mutateRows_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.mutateRows_call(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.mutateRows_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRows_call
-
- Hbase.AsyncClient.mutateRowsTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.mutateRowsTs_call(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.mutateRowsTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowsTs_call
-
- Hbase.AsyncClient.mutateRowTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.mutateRowTs_call(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.mutateRowTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.mutateRowTs_call
-
- Hbase.AsyncClient.scannerClose_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerClose_call(int, AsyncMethodCallback<Hbase.AsyncClient.scannerClose_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerClose_call
-
- Hbase.AsyncClient.scannerGet_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerGet_call(int, AsyncMethodCallback<Hbase.AsyncClient.scannerGet_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGet_call
-
- Hbase.AsyncClient.scannerGetList_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerGetList_call(int, int, AsyncMethodCallback<Hbase.AsyncClient.scannerGetList_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerGetList_call
-
- Hbase.AsyncClient.scannerOpen_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerOpen_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpen_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpen_call
-
- Hbase.AsyncClient.scannerOpenTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerOpenTs_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenTs_call
-
- Hbase.AsyncClient.scannerOpenWithPrefix_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerOpenWithPrefix_call(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithPrefix_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithPrefix_call
-
- Hbase.AsyncClient.scannerOpenWithScan_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerOpenWithScan_call(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithScan_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithScan_call
-
- Hbase.AsyncClient.scannerOpenWithStop_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerOpenWithStop_call(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStop_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStop_call
-
- Hbase.AsyncClient.scannerOpenWithStopTs_call - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.AsyncClient.scannerOpenWithStopTs_call(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStopTs_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.scannerOpenWithStopTs_call
-
- Hbase.AsyncIface - Interface in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.atomicIncrement_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.atomicIncrement_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- Hbase.atomicIncrement_args(ByteBuffer, ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- Hbase.atomicIncrement_args(Hbase.atomicIncrement_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
Performs a deep copy on other.
- Hbase.atomicIncrement_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.atomicIncrement_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.atomicIncrement_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- Hbase.atomicIncrement_result(long, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- Hbase.atomicIncrement_result(Hbase.atomicIncrement_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
Performs a deep copy on other.
- Hbase.atomicIncrement_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.checkAndPut_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.checkAndPut_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- Hbase.checkAndPut_args(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- Hbase.checkAndPut_args(Hbase.checkAndPut_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
Performs a deep copy on other.
- Hbase.checkAndPut_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.checkAndPut_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.checkAndPut_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- Hbase.checkAndPut_result(boolean, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- Hbase.checkAndPut_result(Hbase.checkAndPut_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
Performs a deep copy on other.
- Hbase.checkAndPut_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.Client - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Client(TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- Hbase.Client(TProtocol, TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- Hbase.Client.Factory - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Client.Factory() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client.Factory
-
- Hbase.compact_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.compact_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- Hbase.compact_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- Hbase.compact_args(Hbase.compact_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
Performs a deep copy on other.
- Hbase.compact_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.compact_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.compact_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- Hbase.compact_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- Hbase.compact_result(Hbase.compact_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
Performs a deep copy on other.
- Hbase.compact_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.createTable_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.createTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- Hbase.createTable_args(ByteBuffer, List<ColumnDescriptor>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- Hbase.createTable_args(Hbase.createTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
Performs a deep copy on other.
- Hbase.createTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.createTable_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.createTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- Hbase.createTable_result(IOError, IllegalArgument, AlreadyExists) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- Hbase.createTable_result(Hbase.createTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
Performs a deep copy on other.
- Hbase.createTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAll_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAll_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- Hbase.deleteAll_args(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- Hbase.deleteAll_args(Hbase.deleteAll_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Performs a deep copy on other.
- Hbase.deleteAll_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAll_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAll_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- Hbase.deleteAll_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- Hbase.deleteAll_result(Hbase.deleteAll_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
Performs a deep copy on other.
- Hbase.deleteAll_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAllRow_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAllRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- Hbase.deleteAllRow_args(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- Hbase.deleteAllRow_args(Hbase.deleteAllRow_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Performs a deep copy on other.
- Hbase.deleteAllRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAllRow_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAllRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- Hbase.deleteAllRow_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- Hbase.deleteAllRow_result(Hbase.deleteAllRow_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
Performs a deep copy on other.
- Hbase.deleteAllRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAllRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAllRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- Hbase.deleteAllRowTs_args(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- Hbase.deleteAllRowTs_args(Hbase.deleteAllRowTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Performs a deep copy on other.
- Hbase.deleteAllRowTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAllRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAllRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- Hbase.deleteAllRowTs_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- Hbase.deleteAllRowTs_result(Hbase.deleteAllRowTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
Performs a deep copy on other.
- Hbase.deleteAllRowTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAllTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAllTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- Hbase.deleteAllTs_args(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- Hbase.deleteAllTs_args(Hbase.deleteAllTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Performs a deep copy on other.
- Hbase.deleteAllTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteAllTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteAllTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- Hbase.deleteAllTs_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- Hbase.deleteAllTs_result(Hbase.deleteAllTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
Performs a deep copy on other.
- Hbase.deleteAllTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteTable_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- Hbase.deleteTable_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- Hbase.deleteTable_args(Hbase.deleteTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
Performs a deep copy on other.
- Hbase.deleteTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.deleteTable_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.deleteTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- Hbase.deleteTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- Hbase.deleteTable_result(Hbase.deleteTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
Performs a deep copy on other.
- Hbase.deleteTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.disableTable_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.disableTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- Hbase.disableTable_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- Hbase.disableTable_args(Hbase.disableTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
Performs a deep copy on other.
- Hbase.disableTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.disableTable_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.disableTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- Hbase.disableTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- Hbase.disableTable_result(Hbase.disableTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
Performs a deep copy on other.
- Hbase.disableTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.enableTable_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.enableTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- Hbase.enableTable_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- Hbase.enableTable_args(Hbase.enableTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
Performs a deep copy on other.
- Hbase.enableTable_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.enableTable_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.enableTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- Hbase.enableTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- Hbase.enableTable_result(Hbase.enableTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
Performs a deep copy on other.
- Hbase.enableTable_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.get_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.get_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- Hbase.get_args(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- Hbase.get_args(Hbase.get_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Performs a deep copy on other.
- Hbase.get_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.get_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.get_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- Hbase.get_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- Hbase.get_result(Hbase.get_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
Performs a deep copy on other.
- Hbase.get_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getColumnDescriptors_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getColumnDescriptors_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- Hbase.getColumnDescriptors_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- Hbase.getColumnDescriptors_args(Hbase.getColumnDescriptors_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
Performs a deep copy on other.
- Hbase.getColumnDescriptors_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getColumnDescriptors_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getColumnDescriptors_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- Hbase.getColumnDescriptors_result(Map<ByteBuffer, ColumnDescriptor>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- Hbase.getColumnDescriptors_result(Hbase.getColumnDescriptors_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
Performs a deep copy on other.
- Hbase.getColumnDescriptors_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRegionInfo_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRegionInfo_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- Hbase.getRegionInfo_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- Hbase.getRegionInfo_args(Hbase.getRegionInfo_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
Performs a deep copy on other.
- Hbase.getRegionInfo_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRegionInfo_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRegionInfo_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- Hbase.getRegionInfo_result(TRegionInfo, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- Hbase.getRegionInfo_result(Hbase.getRegionInfo_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
Performs a deep copy on other.
- Hbase.getRegionInfo_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRow_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- Hbase.getRow_args(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- Hbase.getRow_args(Hbase.getRow_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
Performs a deep copy on other.
- Hbase.getRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRow_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- Hbase.getRow_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- Hbase.getRow_result(Hbase.getRow_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
Performs a deep copy on other.
- Hbase.getRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowOrBefore_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowOrBefore_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- Hbase.getRowOrBefore_args(ByteBuffer, ByteBuffer, ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- Hbase.getRowOrBefore_args(Hbase.getRowOrBefore_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
Performs a deep copy on other.
- Hbase.getRowOrBefore_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowOrBefore_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowOrBefore_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- Hbase.getRowOrBefore_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- Hbase.getRowOrBefore_result(Hbase.getRowOrBefore_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
Performs a deep copy on other.
- Hbase.getRowOrBefore_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRows_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRows_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- Hbase.getRows_args(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- Hbase.getRows_args(Hbase.getRows_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
Performs a deep copy on other.
- Hbase.getRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRows_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRows_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- Hbase.getRows_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- Hbase.getRows_result(Hbase.getRows_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
Performs a deep copy on other.
- Hbase.getRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- Hbase.getRowsTs_args(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- Hbase.getRowsTs_args(Hbase.getRowsTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Performs a deep copy on other.
- Hbase.getRowsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- Hbase.getRowsTs_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- Hbase.getRowsTs_result(Hbase.getRowsTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
Performs a deep copy on other.
- Hbase.getRowsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowsWithColumns_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowsWithColumns_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- Hbase.getRowsWithColumns_args(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- Hbase.getRowsWithColumns_args(Hbase.getRowsWithColumns_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Performs a deep copy on other.
- Hbase.getRowsWithColumns_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowsWithColumns_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowsWithColumns_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- Hbase.getRowsWithColumns_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- Hbase.getRowsWithColumns_result(Hbase.getRowsWithColumns_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
Performs a deep copy on other.
- Hbase.getRowsWithColumns_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowsWithColumnsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowsWithColumnsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- Hbase.getRowsWithColumnsTs_args(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- Hbase.getRowsWithColumnsTs_args(Hbase.getRowsWithColumnsTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Performs a deep copy on other.
- Hbase.getRowsWithColumnsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowsWithColumnsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowsWithColumnsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- Hbase.getRowsWithColumnsTs_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- Hbase.getRowsWithColumnsTs_result(Hbase.getRowsWithColumnsTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
Performs a deep copy on other.
- Hbase.getRowsWithColumnsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- Hbase.getRowTs_args(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- Hbase.getRowTs_args(Hbase.getRowTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Performs a deep copy on other.
- Hbase.getRowTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- Hbase.getRowTs_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- Hbase.getRowTs_result(Hbase.getRowTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
Performs a deep copy on other.
- Hbase.getRowTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowWithColumns_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowWithColumns_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- Hbase.getRowWithColumns_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- Hbase.getRowWithColumns_args(Hbase.getRowWithColumns_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Performs a deep copy on other.
- Hbase.getRowWithColumns_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowWithColumns_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowWithColumns_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- Hbase.getRowWithColumns_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- Hbase.getRowWithColumns_result(Hbase.getRowWithColumns_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
Performs a deep copy on other.
- Hbase.getRowWithColumns_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowWithColumnsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowWithColumnsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- Hbase.getRowWithColumnsTs_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- Hbase.getRowWithColumnsTs_args(Hbase.getRowWithColumnsTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Performs a deep copy on other.
- Hbase.getRowWithColumnsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getRowWithColumnsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getRowWithColumnsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- Hbase.getRowWithColumnsTs_result(List<TRowResult>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- Hbase.getRowWithColumnsTs_result(Hbase.getRowWithColumnsTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
Performs a deep copy on other.
- Hbase.getRowWithColumnsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getTableNames_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getTableNames_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- Hbase.getTableNames_args(Hbase.getTableNames_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
Performs a deep copy on other.
- Hbase.getTableNames_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getTableNames_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getTableNames_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- Hbase.getTableNames_result(List<ByteBuffer>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- Hbase.getTableNames_result(Hbase.getTableNames_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
Performs a deep copy on other.
- Hbase.getTableNames_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getTableRegions_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getTableRegions_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- Hbase.getTableRegions_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- Hbase.getTableRegions_args(Hbase.getTableRegions_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
Performs a deep copy on other.
- Hbase.getTableRegions_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getTableRegions_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getTableRegions_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- Hbase.getTableRegions_result(List<TRegionInfo>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- Hbase.getTableRegions_result(Hbase.getTableRegions_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
Performs a deep copy on other.
- Hbase.getTableRegions_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getVer_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getVer_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- Hbase.getVer_args(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- Hbase.getVer_args(Hbase.getVer_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Performs a deep copy on other.
- Hbase.getVer_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getVer_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getVer_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- Hbase.getVer_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- Hbase.getVer_result(Hbase.getVer_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
Performs a deep copy on other.
- Hbase.getVer_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getVerTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getVerTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- Hbase.getVerTs_args(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- Hbase.getVerTs_args(Hbase.getVerTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Performs a deep copy on other.
- Hbase.getVerTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.getVerTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.getVerTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- Hbase.getVerTs_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- Hbase.getVerTs_result(Hbase.getVerTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
Performs a deep copy on other.
- Hbase.getVerTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.Iface - Interface in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.increment_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.increment_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- Hbase.increment_args(TIncrement) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- Hbase.increment_args(Hbase.increment_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
Performs a deep copy on other.
- Hbase.increment_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.increment_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.increment_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- Hbase.increment_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- Hbase.increment_result(Hbase.increment_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
Performs a deep copy on other.
- Hbase.increment_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.incrementRows_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.incrementRows_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- Hbase.incrementRows_args(List<TIncrement>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- Hbase.incrementRows_args(Hbase.incrementRows_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
Performs a deep copy on other.
- Hbase.incrementRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.incrementRows_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.incrementRows_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- Hbase.incrementRows_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- Hbase.incrementRows_result(Hbase.incrementRows_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
Performs a deep copy on other.
- Hbase.incrementRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.isTableEnabled_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.isTableEnabled_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- Hbase.isTableEnabled_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- Hbase.isTableEnabled_args(Hbase.isTableEnabled_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
Performs a deep copy on other.
- Hbase.isTableEnabled_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.isTableEnabled_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.isTableEnabled_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- Hbase.isTableEnabled_result(boolean, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- Hbase.isTableEnabled_result(Hbase.isTableEnabled_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
Performs a deep copy on other.
- Hbase.isTableEnabled_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.majorCompact_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.majorCompact_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- Hbase.majorCompact_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- Hbase.majorCompact_args(Hbase.majorCompact_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
Performs a deep copy on other.
- Hbase.majorCompact_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.majorCompact_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.majorCompact_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- Hbase.majorCompact_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- Hbase.majorCompact_result(Hbase.majorCompact_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
Performs a deep copy on other.
- Hbase.majorCompact_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRow_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- Hbase.mutateRow_args(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- Hbase.mutateRow_args(Hbase.mutateRow_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Performs a deep copy on other.
- Hbase.mutateRow_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRow_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- Hbase.mutateRow_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- Hbase.mutateRow_result(Hbase.mutateRow_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
Performs a deep copy on other.
- Hbase.mutateRow_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRows_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRows_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- Hbase.mutateRows_args(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- Hbase.mutateRows_args(Hbase.mutateRows_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
Performs a deep copy on other.
- Hbase.mutateRows_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRows_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRows_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- Hbase.mutateRows_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- Hbase.mutateRows_result(Hbase.mutateRows_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
Performs a deep copy on other.
- Hbase.mutateRows_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRowsTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRowsTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- Hbase.mutateRowsTs_args(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- Hbase.mutateRowsTs_args(Hbase.mutateRowsTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Performs a deep copy on other.
- Hbase.mutateRowsTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRowsTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRowsTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- Hbase.mutateRowsTs_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- Hbase.mutateRowsTs_result(Hbase.mutateRowsTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
Performs a deep copy on other.
- Hbase.mutateRowsTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRowTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- Hbase.mutateRowTs_args(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- Hbase.mutateRowTs_args(Hbase.mutateRowTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Performs a deep copy on other.
- Hbase.mutateRowTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.mutateRowTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.mutateRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- Hbase.mutateRowTs_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- Hbase.mutateRowTs_result(Hbase.mutateRowTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
Performs a deep copy on other.
- Hbase.mutateRowTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.Processor<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor(I) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor
-
- Hbase.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor
-
- Hbase.Processor.append<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.append() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.append
-
- Hbase.Processor.atomicIncrement<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.atomicIncrement() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.atomicIncrement
-
- Hbase.Processor.checkAndPut<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.checkAndPut() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.checkAndPut
-
- Hbase.Processor.compact<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.compact() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.compact
-
- Hbase.Processor.createTable<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.createTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.createTable
-
- Hbase.Processor.deleteAll<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.deleteAll() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAll
-
- Hbase.Processor.deleteAllRow<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.deleteAllRow() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRow
-
- Hbase.Processor.deleteAllRowTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.deleteAllRowTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRowTs
-
- Hbase.Processor.deleteAllTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.deleteAllTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllTs
-
- Hbase.Processor.deleteTable<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.deleteTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteTable
-
- Hbase.Processor.disableTable<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.disableTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.disableTable
-
- Hbase.Processor.enableTable<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.enableTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.enableTable
-
- Hbase.Processor.get<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.get() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.get
-
- Hbase.Processor.getColumnDescriptors<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getColumnDescriptors() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getColumnDescriptors
-
- Hbase.Processor.getRegionInfo<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getRegionInfo() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRegionInfo
-
- Hbase.Processor.getRow<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getRow() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRow
-
- Hbase.Processor.getRowOrBefore<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getRowOrBefore() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowOrBefore
-
- Hbase.Processor.getRows<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getRows() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRows
-
- Hbase.Processor.getRowsTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getRowsTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsTs
-
- Hbase.Processor.getRowsWithColumns<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getRowsWithColumns() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumns
-
- Hbase.Processor.getRowsWithColumnsTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getRowsWithColumnsTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowsWithColumnsTs
-
- Hbase.Processor.getRowTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getRowTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowTs
-
- Hbase.Processor.getRowWithColumns<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getRowWithColumns() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumns
-
- Hbase.Processor.getRowWithColumnsTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getRowWithColumnsTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getRowWithColumnsTs
-
- Hbase.Processor.getTableNames<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getTableNames() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableNames
-
- Hbase.Processor.getTableRegions<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getTableRegions() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getTableRegions
-
- Hbase.Processor.getVer<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getVer() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVer
-
- Hbase.Processor.getVerTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.getVerTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.getVerTs
-
- Hbase.Processor.increment<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.increment() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.increment
-
- Hbase.Processor.incrementRows<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.incrementRows() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.incrementRows
-
- Hbase.Processor.isTableEnabled<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.isTableEnabled() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.isTableEnabled
-
- Hbase.Processor.majorCompact<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.majorCompact() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.majorCompact
-
- Hbase.Processor.mutateRow<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.mutateRow() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRow
-
- Hbase.Processor.mutateRows<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.mutateRows() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRows
-
- Hbase.Processor.mutateRowsTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.mutateRowsTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowsTs
-
- Hbase.Processor.mutateRowTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.mutateRowTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.mutateRowTs
-
- Hbase.Processor.scannerClose<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.scannerClose() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerClose
-
- Hbase.Processor.scannerGet<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.scannerGet() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGet
-
- Hbase.Processor.scannerGetList<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.scannerGetList() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerGetList
-
- Hbase.Processor.scannerOpen<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.scannerOpen() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpen
-
- Hbase.Processor.scannerOpenTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.scannerOpenTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenTs
-
- Hbase.Processor.scannerOpenWithPrefix<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.scannerOpenWithPrefix() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithPrefix
-
- Hbase.Processor.scannerOpenWithScan<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.scannerOpenWithScan() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithScan
-
- Hbase.Processor.scannerOpenWithStop<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.scannerOpenWithStop() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStop
-
- Hbase.Processor.scannerOpenWithStopTs<I extends Hbase.Iface> - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.Processor.scannerOpenWithStopTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.scannerOpenWithStopTs
-
- Hbase.scannerClose_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerClose_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- Hbase.scannerClose_args(int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- Hbase.scannerClose_args(Hbase.scannerClose_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
Performs a deep copy on other.
- Hbase.scannerClose_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerClose_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerClose_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- Hbase.scannerClose_result(IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- Hbase.scannerClose_result(Hbase.scannerClose_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
Performs a deep copy on other.
- Hbase.scannerClose_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerGet_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerGet_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- Hbase.scannerGet_args(int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- Hbase.scannerGet_args(Hbase.scannerGet_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
Performs a deep copy on other.
- Hbase.scannerGet_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerGet_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerGet_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- Hbase.scannerGet_result(List<TRowResult>, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- Hbase.scannerGet_result(Hbase.scannerGet_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
Performs a deep copy on other.
- Hbase.scannerGet_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerGetList_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerGetList_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- Hbase.scannerGetList_args(int, int) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- Hbase.scannerGetList_args(Hbase.scannerGetList_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
Performs a deep copy on other.
- Hbase.scannerGetList_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerGetList_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerGetList_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- Hbase.scannerGetList_result(List<TRowResult>, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- Hbase.scannerGetList_result(Hbase.scannerGetList_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
Performs a deep copy on other.
- Hbase.scannerGetList_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpen_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpen_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- Hbase.scannerOpen_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- Hbase.scannerOpen_args(Hbase.scannerOpen_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Performs a deep copy on other.
- Hbase.scannerOpen_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpen_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpen_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- Hbase.scannerOpen_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- Hbase.scannerOpen_result(Hbase.scannerOpen_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
Performs a deep copy on other.
- Hbase.scannerOpen_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- Hbase.scannerOpenTs_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- Hbase.scannerOpenTs_args(Hbase.scannerOpenTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Performs a deep copy on other.
- Hbase.scannerOpenTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- Hbase.scannerOpenTs_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- Hbase.scannerOpenTs_result(Hbase.scannerOpenTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
Performs a deep copy on other.
- Hbase.scannerOpenTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithPrefix_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithPrefix_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- Hbase.scannerOpenWithPrefix_args(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- Hbase.scannerOpenWithPrefix_args(Hbase.scannerOpenWithPrefix_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Performs a deep copy on other.
- Hbase.scannerOpenWithPrefix_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithPrefix_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithPrefix_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- Hbase.scannerOpenWithPrefix_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- Hbase.scannerOpenWithPrefix_result(Hbase.scannerOpenWithPrefix_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
Performs a deep copy on other.
- Hbase.scannerOpenWithPrefix_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithScan_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithScan_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- Hbase.scannerOpenWithScan_args(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- Hbase.scannerOpenWithScan_args(Hbase.scannerOpenWithScan_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Performs a deep copy on other.
- Hbase.scannerOpenWithScan_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithScan_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithScan_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- Hbase.scannerOpenWithScan_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- Hbase.scannerOpenWithScan_result(Hbase.scannerOpenWithScan_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
Performs a deep copy on other.
- Hbase.scannerOpenWithScan_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithStop_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithStop_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- Hbase.scannerOpenWithStop_args(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- Hbase.scannerOpenWithStop_args(Hbase.scannerOpenWithStop_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Performs a deep copy on other.
- Hbase.scannerOpenWithStop_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithStop_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithStop_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- Hbase.scannerOpenWithStop_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- Hbase.scannerOpenWithStop_result(Hbase.scannerOpenWithStop_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
Performs a deep copy on other.
- Hbase.scannerOpenWithStop_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithStopTs_args - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithStopTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- Hbase.scannerOpenWithStopTs_args(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- Hbase.scannerOpenWithStopTs_args(Hbase.scannerOpenWithStopTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Performs a deep copy on other.
- Hbase.scannerOpenWithStopTs_args._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- Hbase.scannerOpenWithStopTs_result - Class in org.apache.hadoop.hbase.thrift.generated
-
- Hbase.scannerOpenWithStopTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- Hbase.scannerOpenWithStopTs_result(int, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- Hbase.scannerOpenWithStopTs_result(Hbase.scannerOpenWithStopTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
Performs a deep copy on other.
- Hbase.scannerOpenWithStopTs_result._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- HBASE_AUTH_TOKEN_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Kind
-
HBASE_AUTH_TOKEN = 0;
- HBASE_CELLS_SCANNED_PER_HEARTBEAT_CHECK - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
The number of cells scanned in between timeout checks.
- HBASE_CHECKSUM_VERIFICATION - Static variable in class org.apache.hadoop.hbase.HConstants
-
If this parameter is set to true, then hbase will read
data and then verify checksums.
- HBASE_CLIENT_CONNECTION_IMPL - Static variable in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
Key for configuration in Configuration whose value is the class we implement making a
new HConnection instance.
- HBASE_CLIENT_ENABLE_FAST_FAIL_MODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_CLIENT_FAST_FAIL_CLEANUP_DURATION_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_CLIENT_FAST_FAIL_CLEANUP_MS_DURATION_MS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_CLIENT_FAST_FAIL_INTERCEPTOR_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_CLIENT_FAST_FAIL_MODE_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config for enabling/disabling the fast fail mode.
- HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_CLIENT_FAST_FAIL_THREASHOLD_MS_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_CLIENT_INSTANCE_ID - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for unique identifier for this Configuration
instance.
- HBASE_CLIENT_IPC_POOL_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client IPC pool size
- HBASE_CLIENT_IPC_POOL_TYPE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client IPC pool type
- HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of concurrent connections the client will maintain to a single
Region.
- HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of concurrent connections the client will maintain to a single
RegionServer.
- HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of concurrent connections the client will maintain.
- HBASE_CLIENT_META_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client operation timeout.
- HBASE_CLIENT_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase client operation timeout.
- HBASE_CLIENT_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for client pause value, used mostly as value to wait
before running a retry of a failed get, region lookup, etc.
- HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for maximum retries, used as maximum for all retryable
operations such as fetching of the root region from root region server,
getting a cell's value, starting a row update, etc.
- HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name to set the default scanner caching for all clients.
- HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for maximum number of bytes returned when calling a scanner's next method.
- HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
The client scanner timeout period in milliseconds.
- HBASE_CLUSTER_MINIMUM_MEMORY_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_CONFIG_READ_ZOOKEEPER_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_COORDINATED_STATE_MANAGER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config for pluggable consensus provider
- HBASE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for HBase instance root directory
- HBASE_FLUSH_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.FlushPolicyFactory
-
- HBASE_HSTORE_COMPACTION_MAX_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_COMPACTION_MAX_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_HIGHER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_LOWER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- HBASE_HSTORE_COMPACTION_MAX_THROUGHPUT_OFFPEAK - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- HBASE_HSTORE_COMPACTION_MIN_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_COMPACTION_MIN_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_COMPACTION_RATIO_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_COMPACTION_RATIO_OFFPEAK_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_COMPACTION_THROUGHPUT_TUNE_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- HBASE_HSTORE_MIN_LOCALITY_TO_SKIP_MAJOR_COMPACT - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_OFFPEAK_END_HOUR - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HSTORE_OFFPEAK_START_HOUR - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionConfiguration
-
- HBASE_HTTP_STATIC_USER - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
-
- HBASE_JETTY_LOGS_SERVE_ALIASES - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
-
Enable/Disable aliases serving from jetty
- HBASE_MASTER_LOADBALANCER_CLASS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Config for pluggable load balancers
- HBASE_MASTER_LOGCLEANER_PLUGINS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_META_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for number of versions, kept by meta table.
- HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for number of rows that will be fetched when calling next on
a scanner if it is not served from memory.
- HBASE_META_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for number of versions, kept by meta table.
- HBASE_METRICS_SYSTEM_NAME - Static variable in interface org.apache.hadoop.hbase.metrics.BaseSource
-
- HBASE_NON_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Directories that are not HBase table directories
- HBASE_NON_USER_TABLE_DIRS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Directories that are not HBase user table directories
- HBASE_REGION_SPLIT_POLICY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HBASE_REGIONSERVER_LEASE_PERIOD_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Deprecated.
This config option is deprecated. Will be removed at later releases after 0.96.
- HBASE_RPC_SHORTOPERATION_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
timeout for short operation RPC
- HBASE_RPC_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
timeout for each RPC
- HBASE_RS_HEAP_MEMORY_TUNER_CLASS - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- HBASE_RS_HEAP_MEMORY_TUNER_DEFAULT_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- HBASE_RS_HEAP_MEMORY_TUNER_PERIOD - Static variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- HBASE_RS_NONCES_ENABLED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Whether nonces are enabled; default is true.
- HBASE_SECURITY_AUTHORIZATION_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
-
- HBASE_SECURITY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.User
-
- HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for server pause value, used mostly as value to wait before
running a retry of a failed operation.
- HBASE_SERVER_SCANNER_MAX_RESULT_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for maximum number of bytes returned when calling a scanner's next method.
- HBASE_SNAPSHOT_ENABLED - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Enable or disable snapshot support
- HBASE_SPLITLOG_MANAGER_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for SplitLog manager timeout
- HBASE_SSL_ENABLED_DEFAULT - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
-
- HBASE_SSL_ENABLED_KEY - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
-
Enable/Disable ssl for http server
- HBASE_TEMP_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Temporary directory used for table creation and deletion
- HBASE_THROUGHPUT_CONTROLLER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputControllerFactory
-
- HBASE_VERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- HBaseAdmin - Class in org.apache.hadoop.hbase.client
-
HBaseAdmin is no longer a client API.
- HBaseAdmin(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
-
- HBaseAdmin(Connection) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin
-
- HBaseAdmin.ProcedureFuture<V> - Class in org.apache.hadoop.hbase.client
-
Future that waits on a procedure result.
- HBaseAdmin.ProcedureFuture(HBaseAdmin, Long) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- HBaseAdmin.ProcedureFuture.WaitForStateCallable - Interface in org.apache.hadoop.hbase.client
-
- HBASECLIENT_IMPL - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for what hbase client implementation to use.
- HBaseConfiguration - Class in org.apache.hadoop.hbase
-
Adds HBase configuration files to a Configuration
- HBaseConfiguration() - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
-
Deprecated.
- HBaseConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.HBaseConfiguration
-
Deprecated.
- HBaseConfTool - Class in org.apache.hadoop.hbase.util
-
Tool that prints out a configuration.
- HBaseConfTool() - Constructor for class org.apache.hadoop.hbase.util.HBaseConfTool
-
- HBaseException - Exception in org.apache.hadoop.hbase.exceptions
-
Base checked exception in HBase.
- HBaseException() - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
-
- HBaseException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
-
- HBaseException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
-
- HBaseException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.HBaseException
-
- HBaseFsck - Class in org.apache.hadoop.hbase.util
-
HBaseFsck (hbck) is a tool for checking and repairing region consistency and
table integrity problems in a corrupted HBase.
- HBaseFsck(Configuration) - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck
-
Constructor
- HBaseFsck(Configuration, ExecutorService) - Constructor for class org.apache.hadoop.hbase.util.HBaseFsck
-
Constructor
- HBaseFsck.ErrorReporter - Interface in org.apache.hadoop.hbase.util
-
- HBaseFsck.ErrorReporter.ERROR_CODE - Enum in org.apache.hadoop.hbase.util
-
- HBaseFsck.HbckInfo - Class in org.apache.hadoop.hbase.util
-
Maintain information about a particular region.
- HBaseFsck.RegionRepairException - Exception in org.apache.hadoop.hbase.util
-
Exception thrown when a integrity repair operation fails in an
unresolvable way.
- HBaseFsck.RegionRepairException(String, IOException) - Constructor for exception org.apache.hadoop.hbase.util.HBaseFsck.RegionRepairException
-
- HBaseFsck.TableInfo - Class in org.apache.hadoop.hbase.util
-
Maintain information about a particular table.
- HBaseFsckRepair - Class in org.apache.hadoop.hbase.util
-
This class contains helper methods that repair parts of hbase's filesystem
contents.
- HBaseFsckRepair() - Constructor for class org.apache.hadoop.hbase.util.HBaseFsckRepair
-
- HbaseHandlerMetricsProxy - Class in org.apache.hadoop.hbase.thrift
-
Converts a Hbase.Iface using InvocationHandler so that it reports process
time of each call to ThriftMetrics.
- HBaseHTraceConfiguration - Class in org.apache.hadoop.hbase.trace
-
- HBaseHTraceConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.trace.HBaseHTraceConfiguration
-
- HBaseInterClusterReplicationEndpoint - Class in org.apache.hadoop.hbase.replication.regionserver
-
- HBaseInterClusterReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- HBaseInterfaceAudience - Class in org.apache.hadoop.hbase
-
This class defines constants for different classes of hbase limited private apis
- HBaseInterfaceAudience() - Constructor for class org.apache.hadoop.hbase.HBaseInterfaceAudience
-
- HBaseIOException - Exception in org.apache.hadoop.hbase
-
All hbase specific IOExceptions should be subclasses of HBaseIOException
- HBaseIOException() - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
-
- HBaseIOException(String) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
-
- HBaseIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
-
- HBaseIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.HBaseIOException
-
- HBasePolicyProvider - Class in org.apache.hadoop.hbase.security
-
Implementation of secure Hadoop policy provider for mapping
protocol interfaces to hbase-policy.xml entries.
- HBasePolicyProvider() - Constructor for class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- HBaseProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.BigDecimalMsg - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BigDecimalMsg
- HBaseProtos.BigDecimalMsg.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BigDecimalMsg
- HBaseProtos.BigDecimalMsgOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.BytesBytesPair - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BytesBytesPair
- HBaseProtos.BytesBytesPair.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type BytesBytesPair
- HBaseProtos.BytesBytesPairOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.ColumnFamilySchema - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ColumnFamilySchema
- HBaseProtos.ColumnFamilySchema.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ColumnFamilySchema
- HBaseProtos.ColumnFamilySchemaOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.CompareType - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum CompareType
- HBaseProtos.Coprocessor - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Coprocessor
- HBaseProtos.Coprocessor.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Coprocessor
- HBaseProtos.CoprocessorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.DoubleMsg - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type DoubleMsg
- HBaseProtos.DoubleMsg.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type DoubleMsg
- HBaseProtos.DoubleMsgOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.EmptyMsg - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type EmptyMsg
- HBaseProtos.EmptyMsg.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type EmptyMsg
- HBaseProtos.EmptyMsgOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.FavoredNodes - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FavoredNodes
- HBaseProtos.FavoredNodes.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FavoredNodes
- HBaseProtos.FavoredNodesOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.LongMsg - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type LongMsg
- HBaseProtos.LongMsg.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type LongMsg
- HBaseProtos.LongMsgOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.NameBytesPair - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type NameBytesPair
- HBaseProtos.NameBytesPair.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type NameBytesPair
- HBaseProtos.NameBytesPairOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.NameInt64Pair - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type NameInt64Pair
- HBaseProtos.NameInt64Pair.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type NameInt64Pair
- HBaseProtos.NameInt64PairOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.NamespaceDescriptor - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type NamespaceDescriptor
- HBaseProtos.NamespaceDescriptor.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type NamespaceDescriptor
- HBaseProtos.NamespaceDescriptorOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.NameStringPair - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type NameStringPair
- HBaseProtos.NameStringPair.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type NameStringPair
- HBaseProtos.NameStringPairOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.ProcedureDescription - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ProcedureDescription
- HBaseProtos.ProcedureDescription.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ProcedureDescription
- HBaseProtos.ProcedureDescriptionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.RegionInfo - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionInfo
- HBaseProtos.RegionInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionInfo
- HBaseProtos.RegionInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.RegionServerInfo - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionServerInfo
- HBaseProtos.RegionServerInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionServerInfo
- HBaseProtos.RegionServerInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.RegionSpecifier - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionSpecifier
- HBaseProtos.RegionSpecifier.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RegionSpecifier
- HBaseProtos.RegionSpecifier.RegionSpecifierType - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum RegionSpecifier.RegionSpecifierType
- HBaseProtos.RegionSpecifierOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.ServerName - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ServerName
- HBaseProtos.ServerName.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ServerName
- HBaseProtos.ServerNameOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.SnapshotDescription - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SnapshotDescription
- HBaseProtos.SnapshotDescription.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SnapshotDescription
- HBaseProtos.SnapshotDescription.Type - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum SnapshotDescription.Type
- HBaseProtos.SnapshotDescriptionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.TableName - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type TableName
- HBaseProtos.TableName.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type TableName
- HBaseProtos.TableNameOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.TableSchema - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type TableSchema
- HBaseProtos.TableSchema.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type TableSchema
- HBaseProtos.TableSchemaOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.TimeRange - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type TimeRange
- HBaseProtos.TimeRange.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type TimeRange
- HBaseProtos.TimeRangeOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseProtos.TimeUnit - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum TimeUnit
- HBaseProtos.UUID - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UUID
- HBaseProtos.UUID.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UUID
- HBaseProtos.UUIDOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HBaseReplicationEndpoint - Class in org.apache.hadoop.hbase.replication
-
- HBaseReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- HBaseReplicationEndpoint.PeerRegionServerListener - Class in org.apache.hadoop.hbase.replication
-
Tracks changes to the list of region servers in a peer's cluster.
- HBaseReplicationEndpoint.PeerRegionServerListener(HBaseReplicationEndpoint) - Constructor for class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint.PeerRegionServerListener
-
- HBaseRPCErrorHandler - Interface in org.apache.hadoop.hbase.ipc
-
An interface for calling out of RPC for error conditions.
- HBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
-
A utility class that encapsulates SASL logic for RPC client.
- HBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Create a HBaseSaslRpcClient for an authentication method
- HBaseSaslRpcClient(AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Create a HBaseSaslRpcClient for an authentication method
- HBaseSaslRpcServer - Class in org.apache.hadoop.hbase.security
-
A utility class for dealing with SASL on RPC server
- HBaseSaslRpcServer() - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer
-
- HBaseSaslRpcServer.SaslDigestCallbackHandler - Class in org.apache.hadoop.hbase.security
-
CallbackHandler for SASL DIGEST-MD5 mechanism
- HBaseSaslRpcServer.SaslDigestCallbackHandler(SecretManager<TokenIdentifier>, RpcServer.Connection) - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslDigestCallbackHandler
-
- HBaseSaslRpcServer.SaslGssCallbackHandler - Class in org.apache.hadoop.hbase.security
-
CallbackHandler for SASL GSSAPI Kerberos mechanism
- HBaseSaslRpcServer.SaslGssCallbackHandler() - Constructor for class org.apache.hadoop.hbase.security.HBaseSaslRpcServer.SaslGssCallbackHandler
-
- HBaseSnapshotException - Exception in org.apache.hadoop.hbase.snapshot
-
General exception base class for when a snapshot fails
- HBaseSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Some exception happened for a snapshot and don't even know the snapshot that it was about
- HBaseSnapshotException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Exception for the given snapshot that has no previous root cause
- HBaseSnapshotException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Exception for the given snapshot due to another exception
- HBaseSnapshotException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.snapshot.HBaseSnapshotException
-
Exception when the description of the snapshot cannot be determined, due to some root other
root cause
- HBaseZeroCopyByteString - Class in com.google.protobuf
-
Helper class to extract byte arrays from ByteString
without copy.
- HBCK_CODE_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
HBCK special code name used as server name when manipulating ZK nodes
- HBCK_CODE_SERVERNAME - Static variable in class org.apache.hadoop.hbase.master.AssignmentManager
-
- HBCK_SIDELINEDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used by HBCK to sideline backup data
- HColumnDescriptor - Class in org.apache.hadoop.hbase
-
An HColumnDescriptor contains information about a column family such as the
number of versions, compression settings, etc.
- HColumnDescriptor() - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
As of release 0.96
(HBASE-5453).
This will be made private in HBase 2.0.0.
Used by Writables and Writables are going away.
- HColumnDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
Construct a column descriptor specifying only the family name
The other attributes are defaulted.
- HColumnDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
Construct a column descriptor specifying only the family name
The other attributes are defaulted.
- HColumnDescriptor(HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
Constructor.
- HColumnDescriptor(byte[], int, String, boolean, boolean, int, String) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
- HColumnDescriptor(byte[], int, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
- HColumnDescriptor(byte[], int, int, KeepDeletedCells, String, boolean, String, boolean, boolean, int, int, String, int) - Constructor for class org.apache.hadoop.hbase.HColumnDescriptor
-
- HConnectable<T> - Class in org.apache.hadoop.hbase.client
-
This class makes it convenient for one to execute a command in the context
of a
HConnection
instance based on the given
Configuration
.
- HConnectable(Configuration) - Constructor for class org.apache.hadoop.hbase.client.HConnectable
-
- HConnection - Interface in org.apache.hadoop.hbase.client
-
- HConnectionManager - Class in org.apache.hadoop.hbase.client
-
Deprecated.
Please use ConnectionFactory instead
- HConstants - Class in org.apache.hadoop.hbase
-
HConstants holds a bunch of HBase-related constants
- HConstants.Modify - Enum in org.apache.hadoop.hbase
-
modifyTable op for replacing the table descriptor
- HConstants.OperationStatusCode - Enum in org.apache.hadoop.hbase
-
Status codes used for return values of bulk operations.
- HDFSBlocksDistribution - Class in org.apache.hadoop.hbase
-
Data structure to describe the distribution of HDFS blocks among hosts.
- HDFSBlocksDistribution() - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
Constructor
- HDFSBlocksDistribution.HostAndWeight - Class in org.apache.hadoop.hbase
-
Stores the hostname and weight for that hostname.
- HDFSBlocksDistribution.HostAndWeight(String, long) - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
Constructor
- HDFSBlocksDistribution.HostAndWeight.WeightComparator - Class in org.apache.hadoop.hbase
-
comparator used to sort hosts based on weight
- HDFSBlocksDistribution.HostAndWeight.WeightComparator() - Constructor for class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight.WeightComparator
-
- head(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a HEAD request
- head(Cluster, String, Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a HEAD request
- head(byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- header - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- HEADER_DEFAULT - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- HEADER_USER_AGENT - Static variable in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
-
- headerSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Returns the size of this block header.
- headerSize(boolean) - Static method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
Maps a minor version to the size of the header.
- headMap(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- headSet(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- headSet(Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- headSet(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- HEALTH_CHORE_WAKE_FREQ - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
The maximum number of health check failures a server can encounter consecutively.
- HEALTH_SCRIPT_LOC - Static variable in class org.apache.hadoop.hbase.HConstants
-
Health script related settings.
- HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HealthCheckChore - Class in org.apache.hadoop.hbase
-
The Class HealthCheckChore for running health checker regularly.
- HealthCheckChore(int, Stoppable, Configuration) - Constructor for class org.apache.hadoop.hbase.HealthCheckChore
-
- heap - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
- heap - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- HEAP_OCCUPANCY_HIGH_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HEAP_OCCUPANCY_LOW_WATERMARK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HeapMemoryManager - Class in org.apache.hadoop.hbase.regionserver
-
Manages tuning of Heap memory using HeapMemoryTuner
.
- HeapMemoryManager.TunerContext - Class in org.apache.hadoop.hbase.regionserver
-
POJO to pass all the relevant information required to do the heap memory tuning.
- HeapMemoryManager.TunerContext() - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- HeapMemoryManager.TunerResult - Class in org.apache.hadoop.hbase.regionserver
-
POJO which holds the result of memory tuning done by HeapMemoryTuner implementation.
- HeapMemoryManager.TunerResult(boolean) - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- HeapMemorySizeUtil - Class in org.apache.hadoop.hbase.io.util
-
- HeapMemorySizeUtil() - Constructor for class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
-
- HeapMemoryTuner - Interface in org.apache.hadoop.hbase.regionserver
-
Makes the decision regarding proper sizing of the heap memory.
- HeapMemStoreLAB - Class in org.apache.hadoop.hbase.regionserver
-
A memstore-local allocation buffer.
- HeapMemStoreLAB() - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
-
- HeapMemStoreLAB(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
-
- HEAPOCCUPANCY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats
-
- heapSize() - Method in class org.apache.hadoop.hbase.client.Mutation
-
- HeapSize - Interface in org.apache.hadoop.hbase.io
-
Implementations can be asked for an estimate of their size in bytes.
- heapSize() - Method in interface org.apache.hadoop.hbase.io.HeapSize
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.BlockCacheKey
-
Strings have two bytes per character due to default Java Unicode encoding
(hence length times 2).
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
HeapSize implementation
NOTE : The heapsize should be altered as and when new state variable are added
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
- heapSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
-
Total size of all elements in this queue.
- heapSize() - Method in class org.apache.hadoop.hbase.KeyValue
-
HeapSize implementation
We do not count the bytes in the rowCache because it should be empty for a KeyValue in the
MemStore.
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Get the entire heap usage for this MemStore not including keys in the
snapshot.
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- heapSize - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
The precomputed heap size of this entry
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Returns the pre-computed and "deep" size of the Entry
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
The total memory usage of this map
- heapSize() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- heapSize() - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- heapSize() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.RegionEntryBuffer
-
- HEAPSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- heapSizeWithoutTags() - Method in class org.apache.hadoop.hbase.KeyValue
-
Deprecated.
- heartbeat(long, int, ServerName) - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- HEARTBEAT_MESSAGE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- heartbeatMessage - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
Saves whether or not the most recent response from the server was a heartbeat message.
- heartbeatNoDetails(long) - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- HFile - Class in org.apache.hadoop.hbase.io.hfile
-
File format for hbase.
- HFile() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile
-
- HFile.CachingBlockReader - Interface in org.apache.hadoop.hbase.io.hfile
-
An abstraction used by the block index.
- HFile.FileInfo - Class in org.apache.hadoop.hbase.io.hfile
-
Metadata for this file.
- HFile.FileInfo() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- HFile.Reader - Interface in org.apache.hadoop.hbase.io.hfile
-
An interface used by clients to open and iterate an
HFile
.
- HFile.Writer - Interface in org.apache.hadoop.hbase.io.hfile
-
API required to write an
HFile
- HFile.WriterFactory - Class in org.apache.hadoop.hbase.io.hfile
-
This variety of ways to construct writers is used throughout the code, and
we want to be able to swap writer implementations.
- HFILE_ARCHIVE_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Directory under /hbase where archived hfiles are stored
- HFILE_ARCHIVE_ZNODE_PARENT - Static variable in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
- HFILE_BLOCK_CACHE_SIZE_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HFILE_BLOCK_CACHE_SIZE_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Configuration key for the size of the block cache
- HFILE_CACHE_REFRESH_PERIOD_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
Conf key for the frequency to attempt to refresh the cache of hfiles currently used in
snapshots (ms)
- HFILE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo
-
- HFILE_NAME_REGEX - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
A non-capture group, for hfiles, so that this can be embedded.
- HFILE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Type
-
HFILE = 1;
- HFileArchiver - Class in org.apache.hadoop.hbase.backup
-
Utility class to handle the removal of HFiles (or the respective
StoreFiles
)
for a HRegion from the
FileSystem
.
- HFileArchiveTableMonitor - Class in org.apache.hadoop.hbase.backup.example
-
Monitor the actual tables for which HFiles are archived for long-term retention (always kept
unless ZK state changes).
- HFileArchiveTableMonitor() - Constructor for class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
- HFileArchiveUtil - Class in org.apache.hadoop.hbase.util
-
Helper class for all utilities related to archival/retrieval of HFiles
- HFileBlock - Class in org.apache.hadoop.hbase.io.hfile
-
Reading
HFile
version 1 and 2 blocks, and writing version 2 blocks.
- HFileBlock.BlockIterator - Interface in org.apache.hadoop.hbase.io.hfile
-
- HFileBlock.BlockWritable - Interface in org.apache.hadoop.hbase.io.hfile
-
Something that can be written into a block.
- HFileBlock.FSReader - Interface in org.apache.hadoop.hbase.io.hfile
-
A full-fledged reader with iteration ability.
- HFileBlock.Writer - Class in org.apache.hadoop.hbase.io.hfile
-
Unified version 2
HFile
block writer.
- HFileBlock.Writer(HFileDataBlockEncoder, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
- HFileBlock.Writer.BufferGrabbingByteArrayOutputStream - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileBlock.Writer.BufferGrabbingByteArrayOutputStream() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer.BufferGrabbingByteArrayOutputStream
-
- HFILEBLOCK_DUMMY_HEADER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Just an array of bytes of the right size.
- HFILEBLOCK_HEADER_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
The size of a version 2 HFile block header, minor version 1.
- HFILEBLOCK_HEADER_SIZE_NO_CHECKSUM - Static variable in class org.apache.hadoop.hbase.HConstants
-
The size data structures with minor version is 0
- HFileBlockDecodingContext - Interface in org.apache.hadoop.hbase.io.encoding
-
A decoding context that is created by a reader's encoder, and is shared
across the reader's all read operations.
- HFileBlockDefaultDecodingContext - Class in org.apache.hadoop.hbase.io.encoding
-
- HFileBlockDefaultDecodingContext(HFileContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
-
- HFileBlockDefaultEncodingContext - Class in org.apache.hadoop.hbase.io.encoding
-
- HFileBlockDefaultEncodingContext(DataBlockEncoding, byte[], HFileContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- HFileBlockEncodingContext - Interface in org.apache.hadoop.hbase.io.encoding
-
An encoding context that is created by a writer's encoder, and is shared
across the writer's whole lifetime.
- HFileBlockIndex - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileBlockIndex() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex
-
- HFileBlockIndex.BlockIndexReader - Class in org.apache.hadoop.hbase.io.hfile
-
The reader will always hold the root level index in the memory.
- HFileBlockIndex.BlockIndexReader(KeyValue.KVComparator, int, HFile.CachingBlockReader) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- HFileBlockIndex.BlockIndexReader(KeyValue.KVComparator, int) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
- HFileBlockIndex.BlockIndexWriter - Class in org.apache.hadoop.hbase.io.hfile
-
Writes the block index into the output stream.
- HFileBlockIndex.BlockIndexWriter() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Creates a single-level block index writer
- HFileBlockIndex.BlockIndexWriter(HFileBlock.Writer, CacheConfig, String) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Creates a multi-level block index writer.
- HFileCleaner - Class in org.apache.hadoop.hbase.master.cleaner
-
This Chore, every time it runs, will clear the HFiles in the hfile archive
folder that are deletable for each HFile cleaner in the chain.
- HFileCleaner(int, Stoppable, Configuration, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.master.cleaner.HFileCleaner
-
- hFileContext - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- HFileContext - Class in org.apache.hadoop.hbase.io.hfile
-
This carries the information on some of the meta data about the HFile.
- HFileContext() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- HFileContext(HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContext
-
Copy constructor
- HFileContext(boolean, boolean, boolean, Compression.Algorithm, boolean, ChecksumType, int, int, DataBlockEncoding, Encryption.Context, long) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- HFileContextBuilder - Class in org.apache.hadoop.hbase.io.hfile
-
A builder that helps in building up the HFileContext
- HFileContextBuilder() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- HFileCorruptionChecker - Class in org.apache.hadoop.hbase.util.hbck
-
This class marches through all of the region's hfiles and verifies that
they are all valid files.
- HFileCorruptionChecker(Configuration, ExecutorService, boolean) - Constructor for class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
- HFileDataBlockEncoder - Interface in org.apache.hadoop.hbase.io.hfile
-
Controls what kind of data block encoding is used.
- HFileDataBlockEncoderImpl - Class in org.apache.hadoop.hbase.io.hfile
-
Do different kinds of data block encoding according to column family
options.
- HFileDataBlockEncoderImpl(DataBlockEncoding) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
Do data block encoding with specified options.
- HFileLink - Class in org.apache.hadoop.hbase.io
-
HFileLink describes a link to an hfile.
- HFileLink(Path, Path, Path) - Constructor for class org.apache.hadoop.hbase.io.HFileLink
-
Dead simple hfile link constructor
- HFileLinkCleaner - Class in org.apache.hadoop.hbase.master.cleaner
-
HFileLink cleaner that determines if a hfile should be deleted.
- HFileLinkCleaner() - Constructor for class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
-
- HFileOutputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
- HFileOutputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
-
Deprecated.
- HFileOutputFormat2 - Class in org.apache.hadoop.hbase.mapreduce
-
Writes HFiles.
- HFileOutputFormat2() - Constructor for class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- HFilePrettyPrinter - Class in org.apache.hadoop.hbase.io.hfile
-
Implements pretty-printing functionality for
HFile
s.
- HFilePrettyPrinter() - Constructor for class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- HFilePrettyPrinter(Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
-
- HFileProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- HFileProtos.FileInfoProto - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FileInfoProto
- HFileProtos.FileInfoProto.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FileInfoProto
- HFileProtos.FileInfoProtoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HFileProtos.FileTrailerProto - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FileTrailerProto
- HFileProtos.FileTrailerProto.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FileTrailerProto
- HFileProtos.FileTrailerProtoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- HFileReaderV2 - Class in org.apache.hadoop.hbase.io.hfile
-
HFile
reader for version 2.
- HFileReaderV2(Path, FixedFileTrailer, FSDataInputStreamWrapper, long, CacheConfig, HFileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
Opens a HFile.
- HFileReaderV2.AbstractScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileReaderV2.AbstractScannerV2(HFileReaderV2, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- HFileReaderV2.EncodedScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
-
ScannerV2 that operates on encoded data blocks.
- HFileReaderV2.EncodedScannerV2(HFileReaderV2, boolean, boolean, boolean, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- HFileReaderV2.ScannerV2 - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileReaderV2.ScannerV2(HFileReaderV2, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- HFileReaderV3 - Class in org.apache.hadoop.hbase.io.hfile
-
HFile
reader for version 3.
- HFileReaderV3(Path, FixedFileTrailer, FSDataInputStreamWrapper, long, CacheConfig, HFileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV3
-
Opens a HFile.
- HFileReaderV3.EncodedScannerV3 - Class in org.apache.hadoop.hbase.io.hfile
-
ScannerV3 that operates on encoded data blocks.
- HFileReaderV3.EncodedScannerV3(HFileReaderV3, boolean, boolean, boolean, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.EncodedScannerV3
-
- HFileReaderV3.ScannerV3 - Class in org.apache.hadoop.hbase.io.hfile
-
- HFileReaderV3.ScannerV3(HFileReaderV3, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
-
- HFileScanner - Interface in org.apache.hadoop.hbase.io.hfile
-
A scanner allows you to position yourself within a HFile and
scan through it.
- HFileSystem - Class in org.apache.hadoop.hbase.fs
-
An encapsulation for the FileSystem object that hbase uses to access
data.
- HFileSystem(Configuration, boolean) - Constructor for class org.apache.hadoop.hbase.fs.HFileSystem
-
Create a FileSystem object for HBase regionservers.
- HFileSystem(FileSystem) - Constructor for class org.apache.hadoop.hbase.fs.HFileSystem
-
Wrap a FileSystem object within a HFileSystem.
- HFileV1Detector - Class in org.apache.hadoop.hbase.util
-
Tool to detect presence of any HFileV1 in the given directory.
- HFileV1Detector() - Constructor for class org.apache.hadoop.hbase.util.HFileV1Detector
-
- HFileWriterV2 - Class in org.apache.hadoop.hbase.io.hfile
-
Writes HFile format version 2.
- HFileWriterV2(Configuration, CacheConfig, FileSystem, Path, FSDataOutputStream, KeyValue.KVComparator, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
Constructor that takes a path, creates and closes the output stream.
- HFileWriterV3 - Class in org.apache.hadoop.hbase.io.hfile
-
HFile
writer for version 3.
- HFileWriterV3(Configuration, CacheConfig, FileSystem, Path, FSDataOutputStream, KeyValue.KVComparator, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
-
Constructor that takes a path, creates and closes the output stream.
- hfs - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
The filesystem used for accesing data
- HIGH_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- higher(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- hint - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- HINT_LOOKAHEAD - Static variable in class org.apache.hadoop.hbase.client.Scan
-
Deprecated.
without replacement
This is now a no-op, SEEKs and SKIPs are optimizated automatically.
Will be removed in 2.0+
- hit(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheStats
-
- HLogInputFormat - Class in org.apache.hadoop.hbase.mapreduce
-
- HLogInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
Deprecated.
- HLogKey - Class in org.apache.hadoop.hbase.regionserver.wal
-
- HLogKey() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
- HLogKey(byte[], TableName, long, long, UUID) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
- HLogKey(byte[], TableName) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
- HLogKey(byte[], TableName, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
- HLogKey(byte[], TableName, long, long, List<UUID>, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
Create the log key for writing to somewhere.
- HLogKey(byte[], TableName, long, List<UUID>, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
Create the log key for writing to somewhere.
- HLogKey(byte[], TableName, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogKey
-
Deprecated.
Create the log key for writing to somewhere.
- HLogPrettyPrinter - Class in org.apache.hadoop.hbase.regionserver.wal
-
Deprecated.
use the "hbase wal" command
- HLogPrettyPrinter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
Deprecated.
Basic constructor that simply initializes values to reasonable defaults.
- HLogPrettyPrinter(boolean, boolean, long, String, String, boolean, PrintStream) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.HLogPrettyPrinter
-
Deprecated.
Fully specified constructor.
- HMaster - Class in org.apache.hadoop.hbase.master
-
HMaster is the "master server" for HBase.
- HMaster(Configuration, CoordinatedStateManager) - Constructor for class org.apache.hadoop.hbase.master.HMaster
-
Initializes the HMaster.
- HMaster.RedirectServlet - Class in org.apache.hadoop.hbase.master
-
- HMaster.RedirectServlet() - Constructor for class org.apache.hadoop.hbase.master.HMaster.RedirectServlet
-
- HMasterCommandLine - Class in org.apache.hadoop.hbase.master
-
- HMasterCommandLine(Class<? extends HMaster>) - Constructor for class org.apache.hadoop.hbase.master.HMasterCommandLine
-
- HMasterCommandLine.LocalHMaster - Class in org.apache.hadoop.hbase.master
-
- HMasterCommandLine.LocalHMaster(Configuration, CoordinatedStateManager) - Constructor for class org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
-
- hMemManager - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- host - Static variable in class org.apache.hadoop.hbase.thrift.DemoClient
-
- host - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
-
- HOST_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- hostAddress - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- hostName(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Set the hostname of the http server.
- HOSTNAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- HOSTNAME_PORT_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Addressing
-
- HOUR_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HOURS_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeUnit
-
HOURS = 6;
- HQuorumPeer - Class in org.apache.hadoop.hbase.zookeeper
-
HBase's version of ZooKeeper's QuorumPeer.
- HQuorumPeer() - Constructor for class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
-
- HRegion - Class in org.apache.hadoop.hbase.regionserver
-
- HRegion(Path, WAL, FileSystem, Configuration, HRegionInfo, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
-
Deprecated.
- HRegion(HRegionFileSystem, WAL, Configuration, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion
-
HRegion constructor.
- HRegion.FlushResultImpl - Class in org.apache.hadoop.hbase.regionserver
-
Objects from this class are created when flushing to describe all the different states that
that method ends up in.
- HRegion.RowLockImpl - Class in org.apache.hadoop.hbase.regionserver
-
- HRegion.RowLockImpl() - Constructor for class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
-
- HREGION_COLUMNFAMILY_FLUSH_SIZE_LOWER_BOUND - Static variable in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
-
- HREGION_COMPACTIONDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used to construct the name of the compaction directory during compaction
- HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- HREGION_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used to construct the name of the log directory for a region server
- HREGION_MAX_FILESIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Conf key for the max file size after which we split the region
- HREGION_MEMSTORE_BLOCK_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Block updates if memstore has hbase.hregion.memstore.block.multiplier
times hbase.hregion.memstore.flush.size bytes.
- HREGION_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Conf key for the memstore size at which we flush the memstore
- HREGION_OLDLOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Like the previous, but for old logs that are about to be deleted
- HREGION_VERSION - Static variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
-
- HRegionFileSystem - Class in org.apache.hadoop.hbase.regionserver
-
View to an on-disk Region.
- HRegionInfo - Class in org.apache.hadoop.hbase
-
Information about a region.
- HRegionInfo(long, TableName, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
- HRegionInfo() - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Deprecated.
As of release 0.96
(HBASE-5453).
This will be removed in HBase 2.0.0.
Used by Writables and Writables are going away.
- HRegionInfo(TableName) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
- HRegionInfo(TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Construct HRegionInfo with explicit parameters
- HRegionInfo(TableName, byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Construct HRegionInfo with explicit parameters
- HRegionInfo(TableName, byte[], byte[], boolean, long) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Construct HRegionInfo with explicit parameters
- HRegionInfo(TableName, byte[], byte[], boolean, long, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Construct HRegionInfo with explicit parameters
- HRegionInfo(HRegionInfo) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
Costruct a copy of another HRegionInfo
- HRegionInfo(HRegionInfo, int) - Constructor for class org.apache.hadoop.hbase.HRegionInfo
-
- HRegionLocation - Class in org.apache.hadoop.hbase
-
Data structure to hold HRegionInfo and the address for the hosting
HRegionServer.
- HRegionLocation(HRegionInfo, ServerName) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
-
- HRegionLocation(HRegionInfo, ServerName, long) - Constructor for class org.apache.hadoop.hbase.HRegionLocation
-
- HRegionLocator - Class in org.apache.hadoop.hbase.client
-
- HRegionLocator(TableName, ClusterConnection) - Constructor for class org.apache.hadoop.hbase.client.HRegionLocator
-
- HRegionPartitioner<K2,V2> - Class in org.apache.hadoop.hbase.mapred
-
This is used to partition the output keys into groups of keys.
- HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapred.HRegionPartitioner
-
- HRegionPartitioner<KEY,VALUE> - Class in org.apache.hadoop.hbase.mapreduce
-
This is used to partition the output keys into groups of keys.
- HRegionPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
- HRegionServer - Class in org.apache.hadoop.hbase.regionserver
-
HRegionServer makes a set of HRegions available to clients.
- HRegionServer(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Starts a HRegionServer at the default location.
- HRegionServer(Configuration, CoordinatedStateManager) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Starts a HRegionServer at the default location
- HRegionServer.MovedRegionsCleaner - Class in org.apache.hadoop.hbase.regionserver
-
Creates a Chore thread to clean the moved region cache.
- HRegionServerCommandLine - Class in org.apache.hadoop.hbase.regionserver
-
Class responsible for parsing the command line and starting the
RegionServer.
- HRegionServerCommandLine(Class<? extends HRegionServer>) - Constructor for class org.apache.hadoop.hbase.regionserver.HRegionServerCommandLine
-
- HStore - Class in org.apache.hadoop.hbase.regionserver
-
A Store holds a column family in a Region.
- HStore(HRegion, HColumnDescriptor, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.HStore
-
Constructor
- HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
The max number of threads used for opening and closing stores or store
files in parallel
- HTable - Class in org.apache.hadoop.hbase.client
-
An implementation of
Table
.
- HTable(Configuration, String) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
Constructing HTable objects manually has been deprecated. Please use
Connection
to instantiate a Table
instead.
- HTable(Configuration, byte[]) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
Constructing HTable objects manually has been deprecated. Please use
Connection
to instantiate a Table
instead.
- HTable(Configuration, TableName) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
Constructing HTable objects manually has been deprecated. Please use
Connection
to instantiate a Table
instead.
- HTable(TableName, Connection) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
- HTable(Configuration, byte[], ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
Constructing HTable objects manually has been deprecated. Please use
Connection
to instantiate a Table
instead.
- HTable(Configuration, TableName, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
Constructing HTable objects manually has been deprecated. Please use
Connection
to instantiate a Table
instead.
- HTable(byte[], Connection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
Do not use, internal ctor.
- HTable(TableName, Connection, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
Do not use, internal ctor.
- HTable(TableName, ClusterConnection, ConnectionConfiguration, RpcRetryingCallerFactory, RpcControllerFactory, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
Creates an object to access a HBase table.
- HTable(ClusterConnection, BufferedMutatorParams) - Constructor for class org.apache.hadoop.hbase.client.HTable
-
For internal testing.
- HTableDescriptor - Class in org.apache.hadoop.hbase
-
HTableDescriptor contains the details about an HBase table such as the descriptors of
all the column families, is the table a catalog table, -ROOT-
or
hbase:meta
, if the table is read only, the maximum size of the memstore,
when the region split should occur, coprocessors associated with it etc...
- HTableDescriptor(TableName, HColumnDescriptor[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Private constructor used internally creating table descriptors for
catalog tables, hbase:meta
and -ROOT-
.
- HTableDescriptor(TableName, HColumnDescriptor[], Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Private constructor used internally creating table descriptors for
catalog tables, hbase:meta
and -ROOT-
.
- HTableDescriptor() - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
As of release 0.96
(HBASE-5453).
This will be removed in HBase 2.0.0.
Used by Writables and Writables are going away.
- HTableDescriptor(TableName) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Construct a table descriptor specifying a TableName object
- HTableDescriptor(byte[]) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- HTableDescriptor(String) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- HTableDescriptor(HTableDescriptor) - Constructor for class org.apache.hadoop.hbase.HTableDescriptor
-
Construct a table descriptor by cloning the descriptor passed as a parameter.
- hTableDescriptor - Variable in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
- hTableDescriptor - Variable in class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- HTableFactory - Class in org.apache.hadoop.hbase.client
-
- HTableFactory() - Constructor for class org.apache.hadoop.hbase.client.HTableFactory
-
Deprecated.
- HTableInterface - Interface in org.apache.hadoop.hbase.client
-
- HTableInterfaceFactory - Interface in org.apache.hadoop.hbase.client
-
- HTableMultiplexer - Class in org.apache.hadoop.hbase.client
-
HTableMultiplexer provides a thread-safe non blocking PUT API across all the tables.
- HTableMultiplexer(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- HTableMultiplexer(Connection, Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer
-
- HTableMultiplexer.HTableMultiplexerStatus - Class in org.apache.hadoop.hbase.client
-
HTableMultiplexerStatus keeps track of the current status of the HTableMultiplexer.
- HTableMultiplexer.HTableMultiplexerStatus(Map<HRegionLocation, HTableMultiplexer.FlushWorker>) - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer.HTableMultiplexerStatus
-
- HTablePool - Class in org.apache.hadoop.hbase.client
-
- HTablePool() - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Default Constructor.
- HTablePool(Configuration, int) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Constructor to set maximum versions and use the specified configuration.
- HTablePool(Configuration, int, HTableInterfaceFactory) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Constructor to set maximum versions and use the specified configuration and
table factory.
- HTablePool(Configuration, int, PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Constructor to set maximum versions and use the specified configuration and
pool type.
- HTablePool(Configuration, int, HTableInterfaceFactory, PoolMap.PoolType) - Constructor for class org.apache.hadoop.hbase.client.HTablePool
-
Deprecated.
Constructor to set maximum versions and use the specified configuration,
table factory and pool type.
- HTableUtil - Class in org.apache.hadoop.hbase.client
-
- HTableUtil() - Constructor for class org.apache.hadoop.hbase.client.HTableUtil
-
Deprecated.
- HTableWrapper - Class in org.apache.hadoop.hbase.client
-
A wrapper for HTable.
- htd - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- HThreadedSelectorServerArgs - Class in org.apache.hadoop.hbase.thrift
-
A TThreadedSelectorServer.Args that reads hadoop configuration
- HThreadedSelectorServerArgs(TNonblockingServerTransport, Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
- HtmlQuoting - Class in org.apache.hadoop.hbase.http
-
This class is responsible for quoting HTML characters.
- HtmlQuoting() - Constructor for class org.apache.hadoop.hbase.http.HtmlQuoting
-
- HttpAuthenticationException - Exception in org.apache.hadoop.hbase.thrift
-
- HttpAuthenticationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
-
- HttpAuthenticationException(String) - Constructor for exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
-
- HttpAuthenticationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.thrift.HttpAuthenticationException
-
- HttpConfig - Class in org.apache.hadoop.hbase.http
-
Statics to get access to Http related configuration.
- HttpConfig(Configuration) - Constructor for class org.apache.hadoop.hbase.http.HttpConfig
-
- HttpConfig.Policy - Enum in org.apache.hadoop.hbase.http
-
- HttpDoAsClient - Class in org.apache.hadoop.hbase.thrift
-
See the instructions under hbase-examples/README.txt
- HttpRequestLog - Class in org.apache.hadoop.hbase.http
-
RequestLog object for use with Http
- HttpRequestLog() - Constructor for class org.apache.hadoop.hbase.http.HttpRequestLog
-
- HttpRequestLogAppender - Class in org.apache.hadoop.hbase.http
-
Log4j Appender adapter for HttpRequestLog
- HttpRequestLogAppender() - Constructor for class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- HttpServer - Class in org.apache.hadoop.hbase.http
-
Create a Jetty embedded server to answer http requests.
- HttpServer(String, String, int, boolean) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer(String, String, int, boolean, Configuration, Connector) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer(String, String, int, boolean, Configuration, String[]) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer(String, String, int, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer(String, String, int, boolean, Configuration, AccessControlList) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer(String, String, int, boolean, Configuration, AccessControlList, Connector) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer(String, String, int, boolean, Configuration, AccessControlList, Connector, String[]) - Constructor for class org.apache.hadoop.hbase.http.HttpServer
-
Deprecated.
- HttpServer.Builder - Class in org.apache.hadoop.hbase.http
-
Class to construct instances of HTTP server with specific options.
- HttpServer.Builder() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- HttpServer.QuotingInputFilter - Class in org.apache.hadoop.hbase.http
-
A Servlet input filter that quotes all HTML active characters in the
parameter names and values.
- HttpServer.QuotingInputFilter() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
-
- HttpServer.QuotingInputFilter.RequestQuoter - Class in org.apache.hadoop.hbase.http
-
- HttpServer.QuotingInputFilter.RequestQuoter(HttpServletRequest) - Constructor for class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter.RequestQuoter
-
- HttpServer.StackServlet - Class in org.apache.hadoop.hbase.http
-
A very simple servlet to serve up a text representation of the current
stack traces.
- HttpServer.StackServlet() - Constructor for class org.apache.hadoop.hbase.http.HttpServer.StackServlet
-
- HttpServerUtil - Class in org.apache.hadoop.hbase.util
-
HttpServer utility.
- HttpServerUtil() - Constructor for class org.apache.hadoop.hbase.util.HttpServerUtil
-
- humanReadableTimestamp(long) - Static method in class org.apache.hadoop.hbase.KeyValue
-
- humanSize(double) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
-
- humanTimeDiff(long) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
-
- S - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'S'
- SampleUploader - Class in org.apache.hadoop.hbase.mapreduce
-
Sample Uploader MapReduce
- SampleUploader() - Constructor for class org.apache.hadoop.hbase.mapreduce.SampleUploader
-
- sanityCheckLeft(byte[], byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Subclasses can call this method to make sure the first KV is within multi-writer range.
- sanityCheckRight(byte[], byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Subclasses can call this method to make sure the last KV is within multi-writer range.
- SASL_DEFAULT_REALM - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
-
- SASL_PROPS - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
-
- SaslClientHandler - Class in org.apache.hadoop.hbase.security
-
Handles Sasl connections
- SaslClientHandler(UserGroupInformation, AuthMethod, Token<? extends TokenIdentifier>, String, boolean, String, SaslClientHandler.SaslExceptionHandler, SaslClientHandler.SaslSuccessfulConnectHandler) - Constructor for class org.apache.hadoop.hbase.security.SaslClientHandler
-
Constructor
- SaslClientHandler.SaslExceptionHandler - Interface in org.apache.hadoop.hbase.security
-
Handler for exceptions during Sasl connection
- SaslClientHandler.SaslSuccessfulConnectHandler - Interface in org.apache.hadoop.hbase.security
-
Handler for successful connects
- saslConnect(InputStream, OutputStream) - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Do client side SASL authentication with server via the given InputStream
and OutputStream
- saslLatch - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- saslQop - Variable in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
-
- SaslStatus - Enum in org.apache.hadoop.hbase.security
-
- SaslUtil - Class in org.apache.hadoop.hbase.security
-
- SaslUtil() - Constructor for class org.apache.hadoop.hbase.security.SaslUtil
-
- SaslUtil.QualityOfProtection - Enum in org.apache.hadoop.hbase.security
-
- saveMetadata(HFile.Writer) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Save metadata in HFile which will be written to disk
- saveMetadata(HFile.Writer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- saveMetadata(HFile.Writer) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- scan - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- Scan - Class in org.apache.hadoop.hbase.client
-
Used to perform Scan operations.
- Scan() - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Create a Scan operation across all rows.
- Scan(byte[], Filter) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
- Scan(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Create a Scan operation starting at the specified row.
- Scan(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Create a Scan operation for the range of rows specified.
- Scan(Scan) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Creates a new instance of this class while copying all values.
- Scan(Get) - Constructor for class org.apache.hadoop.hbase.client.Scan
-
Builds a scan object with the same specs as get.
- SCAN - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Base-64 encoded scanner.
- scan(RpcController, ClientProtos.ScanRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.BlockingInterface
-
- scan(RpcController, ClientProtos.ScanRequest, RpcCallback<ClientProtos.ScanResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Interface
-
rpc Scan(.ScanRequest) returns (.ScanResponse);
- scan(RpcController, ClientProtos.ScanRequest, RpcCallback<ClientProtos.ScanResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
-
rpc Scan(.ScanRequest) returns (.ScanResponse);
- scan(RpcController, ClientProtos.ScanRequest, RpcCallback<ClientProtos.ScanResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService.Stub
-
- scan(RpcController, ClientProtos.ScanRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Scan data in a table.
- scan - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- scan - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Scan instance
- scan - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
the scan object to get a Scanner for
- scan - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
the scan object to get a Scanner for
- SCAN_ATTRIBUTES_METRICS_DATA - Static variable in class org.apache.hadoop.hbase.client.Scan
-
Deprecated.
- SCAN_ATTRIBUTES_METRICS_ENABLE - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- SCAN_ATTRIBUTES_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.client.Scan
-
- SCAN_BATCH_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_BATCHSIZE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Set the maximum number of values to return for each call to next().
- SCAN_CACHEBLOCKS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Set to false to disable server-side caching of blocks for this scan.
- SCAN_CACHEDROWS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The number of rows for caching that will be passed to scanners.
- SCAN_COLUMN - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_COLUMN_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Column Family to Scan
- SCAN_COLUMNS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Space delimited list of columns and column families to scan.
- SCAN_END_ROW - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_END_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_FETCH_SIZE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- SCAN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest
-
- SCAN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- SCAN_FILTER - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_LIMIT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_MAX_VERSIONS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_MAXVERSIONS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The maximum number of version to return.
- SCAN_NEXT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SCAN_RESULT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse
-
- SCAN_ROW_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Scan start row
- SCAN_ROW_STOP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Scan stop row
- SCAN_START_ROW - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_START_TIME - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- SCAN_TIMERANGE_END - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The ending timestamp used to filter columns with a specific range of versions.
- SCAN_TIMERANGE_START - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The starting timestamp used to filter columns with a specific range of versions.
- SCAN_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
The timestamp used to filter columns with a specific timestamp.
- ScanDeleteTracker - Class in org.apache.hadoop.hbase.regionserver
-
This class is responsible for the tracking and enforcement of Deletes
during the course of a Scan operation.
- ScanDeleteTracker() - Constructor for class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
Constructor for ScanDeleteTracker
- scanFromThrift(TScan) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- ScanInfo - Class in org.apache.hadoop.hbase.regionserver
-
Immutable information for scans over a store.
- ScanInfo(HColumnDescriptor, long, long, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- ScanInfo(byte[], int, int, long, KeepDeletedCells, long, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanInfo
-
- ScanLabelGenerator - Interface in org.apache.hadoop.hbase.security.visibility
-
This would be the interface which would be used add labels to the RPC context
and this would be stored against the UGI.
- scanMetrics - Variable in class org.apache.hadoop.hbase.client.AbstractClientScanner
-
- ScanMetrics - Class in org.apache.hadoop.hbase.client.metrics
-
Provides client-side metrics related to scan operations.
- ScanMetrics() - Constructor for class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
constructor
- scanMetrics - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- scanMetricsPublished - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- SCANNER_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest
-
- SCANNER_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- scannerCaching - Variable in class org.apache.hadoop.hbase.client.HTable
-
- ScannerCallable - Class in org.apache.hadoop.hbase.client
-
Scanner operations such as create, next, etc.
- ScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
-
- ScannerCallable(ClusterConnection, TableName, Scan, ScanMetrics, RpcControllerFactory, int) - Constructor for class org.apache.hadoop.hbase.client.ScannerCallable
-
- scannerClose(int, AsyncMethodCallback<Hbase.AsyncClient.scannerClose_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerClose(int, AsyncMethodCallback<Hbase.AsyncClient.scannerClose_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerClose(int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Closes the server-state associated with an open scanner.
- scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- ScannerContext - Class in org.apache.hadoop.hbase.regionserver
-
- ScannerContext.Builder - Class in org.apache.hadoop.hbase.regionserver
-
- ScannerContext.LimitScope - Enum in org.apache.hadoop.hbase.regionserver
-
The various scopes where a limit can be enforced.
- ScannerContext.NextState - Enum in org.apache.hadoop.hbase.regionserver
-
- scannerGet(int, AsyncMethodCallback<Hbase.AsyncClient.scannerGet_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerGet(int, AsyncMethodCallback<Hbase.AsyncClient.scannerGet_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerGet(int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Returns the scanner's current row value and advances to the next
row in the table.
- scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerGetList(int, int, AsyncMethodCallback<Hbase.AsyncClient.scannerGetList_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerGetList(int, int, AsyncMethodCallback<Hbase.AsyncClient.scannerGetList_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerGetList(int, int) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Returns, starting at the scanner's current row value nbRows worth of
rows and advances to the next row in the table.
- scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerId - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- scannerId - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
the Id of the Scanner to close *
- scannerId - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
the Id of the Scanner to return rows from.
- ScannerInstanceResource - Class in org.apache.hadoop.hbase.rest
-
- ScannerInstanceResource() - Constructor for class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- ScannerInstanceResource(String, String, ResultGenerator, int) - Constructor for class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- scannerMap - Variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerMaxResultSize - Variable in class org.apache.hadoop.hbase.client.HTable
-
- ScannerMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ScannerMessage.Scanner - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.Scanner
- ScannerMessage.Scanner.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.Scanner
- ScannerMessage.ScannerOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- ScannerModel - Class in org.apache.hadoop.hbase.rest.model
-
A representation of Scanner parameters.
- ScannerModel() - Constructor for class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Default constructor
- ScannerModel(byte[], byte[], List<byte[]>, int, int, long, int, String) - Constructor for class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Constructor
- ScannerModel(byte[], byte[], List<byte[]>, int, int, long, long, String) - Constructor for class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Constructor
- scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpen_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpen_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get a scanner on the current table starting at the specified row and
ending at the last row in the table.
- scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get a scanner on the current table starting at the specified row and
ending at the last row in the table.
- scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithPrefix_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithPrefix_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Open a scanner for a given prefix.
- scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithScan_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithScan_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get a scanner on the current table, using the Scan instance
for the scan parameters.
- scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStop_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStop_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get a scanner on the current table starting and stopping at the
specified rows.
- scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStopTs_call>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>, AsyncMethodCallback<Hbase.AsyncClient.scannerOpenWithStopTs_call>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Get a scanner on the current table starting and stopping at the
specified rows.
- scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- ScannerResetException - Exception in org.apache.hadoop.hbase.exceptions
-
Thrown when the server side has received an Exception, and asks the Client to reset the scanner
state by closing the current region scanner, and reopening from the start of last seen row.
- ScannerResetException() - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
-
constructor
- ScannerResetException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
-
Constructor
- ScannerResetException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.exceptions.ScannerResetException
-
- scannerResetException() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- scannerResetException() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- ScannerResource - Class in org.apache.hadoop.hbase.rest
-
- ScannerResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResource
-
Constructor
- ScannerResultGenerator - Class in org.apache.hadoop.hbase.rest
-
- ScannerResultGenerator(String, RowSpec, Filter, boolean) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- ScannerResultGenerator(String, RowSpec, Filter, int, boolean) - Constructor for class org.apache.hadoop.hbase.rest.ScannerResultGenerator
-
- scannerTimeout - Variable in class org.apache.hadoop.hbase.client.ClientScanner
-
- ScannerTimeoutException - Exception in org.apache.hadoop.hbase.client
-
Thrown when a scanner has timed out.
- ScanQueryMatcher - Class in org.apache.hadoop.hbase.regionserver
-
A query matcher that is specifically designed for the scan case.
- ScanQueryMatcher(Scan, ScanInfo, NavigableSet<byte[]>, ScanType, long, long, long, long, RegionCoprocessorHost) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
Construct a QueryMatcher for a scan
- ScanQueryMatcher(Scan, ScanInfo, NavigableSet<byte[]>, long, long, long, long, byte[], byte[], RegionCoprocessorHost) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
Construct a QueryMatcher for a scan that drop deletes from a limited range of rows.
- ScanQueryMatcher.MatchCode - Enum in org.apache.hadoop.hbase.regionserver
-
- SCANS - Static variable in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Job parameter that specifies the scan list.
- ScanType - Enum in org.apache.hadoop.hbase.regionserver
-
Enum to distinguish general scan types.
- ScanWildcardColumnTracker - Class in org.apache.hadoop.hbase.regionserver
-
Keeps track of the columns for a scan if they are not explicitly specified
- ScanWildcardColumnTracker(int, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
Return maxVersions of every row.
- scheduleChore(ScheduledChore) - Method in class org.apache.hadoop.hbase.ChoreService
-
- ScheduledChore - Class in org.apache.hadoop.hbase
-
ScheduledChore is a task performed on a period in hbase.
- ScheduledChore() - Constructor for class org.apache.hadoop.hbase.ScheduledChore
-
This constructor is for test only.
- ScheduledChore(String, Stoppable, int) - Constructor for class org.apache.hadoop.hbase.ScheduledChore
-
- ScheduledChore(String, Stoppable, int, long) - Constructor for class org.apache.hadoop.hbase.ScheduledChore
-
- ScheduledChore(String, Stoppable, int, long, TimeUnit) - Constructor for class org.apache.hadoop.hbase.ScheduledChore
-
- SchemaResource - Class in org.apache.hadoop.hbase.rest
-
- SchemaResource(TableResource) - Constructor for class org.apache.hadoop.hbase.rest.SchemaResource
-
Constructor
- SCOPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- SCOPE_TYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope
-
- SCOPES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey
-
- scopeWALEdits(HTableDescriptor, WALKey, WALEdit) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Utility method used to set the correct scopes on each log key.
- ScopeWALEntryFilter - Class in org.apache.hadoop.hbase.replication
-
Keeps KVs that are scoped other than local
- ScopeWALEntryFilter() - Constructor for class org.apache.hadoop.hbase.replication.ScopeWALEntryFilter
-
- second - Variable in class org.apache.hadoop.hbase.util.Pair
-
- SECOND_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair
-
- SECOND_PART_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse
-
- SECONDS_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeUnit
-
SECONDS = 4;
- secretManager - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- SecureBulkLoadClient - Class in org.apache.hadoop.hbase.client.coprocessor
-
Client proxy for SecureBulkLoadProtocol
used in conjunction with SecureBulkLoadEndpoint
- SecureBulkLoadClient(Table) - Constructor for class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
-
- SecureBulkLoadEndpoint - Class in org.apache.hadoop.hbase.security.access
-
Coprocessor service for bulk loads in secure mode.
- SecureBulkLoadEndpoint() - Constructor for class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- secureBulkLoadHFiles(RpcController, SecureBulkLoadProtos.SecureBulkLoadHFilesRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.BlockingInterface
-
- secureBulkLoadHFiles(RpcController, SecureBulkLoadProtos.SecureBulkLoadHFilesRequest, RpcCallback<SecureBulkLoadProtos.SecureBulkLoadHFilesResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Interface
-
rpc SecureBulkLoadHFiles(.SecureBulkLoadHFilesRequest) returns (.SecureBulkLoadHFilesResponse);
- secureBulkLoadHFiles(RpcController, SecureBulkLoadProtos.SecureBulkLoadHFilesRequest, RpcCallback<SecureBulkLoadProtos.SecureBulkLoadHFilesResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
-
rpc SecureBulkLoadHFiles(.SecureBulkLoadHFilesRequest) returns (.SecureBulkLoadHFilesResponse);
- secureBulkLoadHFiles(RpcController, SecureBulkLoadProtos.SecureBulkLoadHFilesRequest, RpcCallback<SecureBulkLoadProtos.SecureBulkLoadHFilesResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Stub
-
- secureBulkLoadHFiles(RpcController, SecureBulkLoadProtos.SecureBulkLoadHFilesRequest, RpcCallback<SecureBulkLoadProtos.SecureBulkLoadHFilesResponse>) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- SecureBulkLoadProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- SecureBulkLoadProtos.CleanupBulkLoadRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CleanupBulkLoadRequest
- SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CleanupBulkLoadRequest
- SecureBulkLoadProtos.CleanupBulkLoadRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SecureBulkLoadProtos.CleanupBulkLoadResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CleanupBulkLoadResponse
- SecureBulkLoadProtos.CleanupBulkLoadResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CleanupBulkLoadResponse
- SecureBulkLoadProtos.CleanupBulkLoadResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SecureBulkLoadProtos.DelegationToken - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type DelegationToken
- SecureBulkLoadProtos.DelegationToken.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type DelegationToken
- SecureBulkLoadProtos.DelegationTokenOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SecureBulkLoadProtos.PrepareBulkLoadRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type PrepareBulkLoadRequest
- SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type PrepareBulkLoadRequest
- SecureBulkLoadProtos.PrepareBulkLoadRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SecureBulkLoadProtos.PrepareBulkLoadResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type PrepareBulkLoadResponse
- SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type PrepareBulkLoadResponse
- SecureBulkLoadProtos.PrepareBulkLoadResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SecureBulkLoadProtos.SecureBulkLoadHFilesRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SecureBulkLoadHFilesRequest
- SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SecureBulkLoadHFilesRequest
- SecureBulkLoadProtos.SecureBulkLoadHFilesRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SecureBulkLoadProtos.SecureBulkLoadHFilesResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SecureBulkLoadHFilesResponse
- SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SecureBulkLoadHFilesResponse
- SecureBulkLoadProtos.SecureBulkLoadHFilesResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SecureBulkLoadProtos.SecureBulkLoadService - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf service SecureBulkLoadService
- SecureBulkLoadProtos.SecureBulkLoadService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
-
- SecureBulkLoadProtos.SecureBulkLoadService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SecureBulkLoadProtos.SecureBulkLoadService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SecureBulkLoadProtos.SecureBulkLoadService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
-
- SecureBulkLoadUtil - Class in org.apache.hadoop.hbase.security
-
- SecureBulkLoadUtil() - Constructor for class org.apache.hadoop.hbase.security.SecureBulkLoadUtil
-
- SecureProtobufLogReader - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SecureProtobufLogReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
-
- SecureProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SecureProtobufLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
-
- SecureWALCellCodec - Class in org.apache.hadoop.hbase.regionserver.wal
-
A WALCellCodec that encrypts the WALedits.
- SecureWALCellCodec(Configuration, CompressionContext) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- SecureWALCellCodec(Configuration, Encryptor) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- SecureWALCellCodec(Configuration, Decryptor) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SecureWALCellCodec
-
- SecurityInfo - Class in org.apache.hadoop.hbase.security
-
Maps RPC protocol interfaces to required configuration
- SecurityInfo(String, AuthenticationProtos.TokenIdentifier.Kind) - Constructor for class org.apache.hadoop.hbase.security.SecurityInfo
-
- SecurityUtil - Class in org.apache.hadoop.hbase.security
-
Security related generic utility methods.
- SecurityUtil() - Constructor for class org.apache.hadoop.hbase.security.SecurityUtil
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
Set the scanner at the seek key.
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.KeyValueHeap
-
Seeks all scanners at or below the specified seek key.
- seek(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Seek the scanner at or after the specified KeyValue.
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- seek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- seek(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
- seek() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationWALReaderManager
-
Advance the reader to the current position
- seek(Cell) - Method in class org.apache.hadoop.hbase.util.CollectionBackedScanner
-
- seek(long) - Method in interface org.apache.hadoop.hbase.wal.WAL.Reader
-
- seekAsDirection(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Do a reseek in a normal StoreScanner(scan forward)
- seekAtOrAfter(HFileScanner, Cell) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- seekBefore(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- seekBefore(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- seekBefore(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- seekBefore(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Deprecated.
- seekBefore(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Deprecated.
- seekBefore(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- seekForwardTo(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
-
- seekForwardTo(Cell) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.CellSearcher
-
- seekForwardToOrAfter(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
-
- seekForwardToOrAfter(Cell) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.CellSearcher
-
Same as seekForwardTo(..), but go to the extra effort of finding the next key if there's no
exact match.
- seekForwardToOrBefore(Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArraySearcher
-
- seekForwardToOrBefore(Cell) - Method in interface org.apache.hadoop.hbase.codec.prefixtree.scanner.CellSearcher
-
Same as seekForwardTo(..), but go to the extra effort of finding the next key if there's no
exact match.
- seekOnFs(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
-
- seekOnFs(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
-
Performs a filesystem-level seek to a certain position in an underlying file.
- seekOnFs(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- seekScanners(List<? extends KeyValueScanner>, Cell, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Seek the specified scanners with the given key
- seekTo(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- seekTo(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- seekTo(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- seekTo(Cell, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
An internal API function.
- seekTo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.EncodedScannerV2
-
- seekTo() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
Positions this scanner at the start of the file.
- seekTo(byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Deprecated.
- seekTo(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Deprecated.
- seekTo(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
- seekTo() - Method in interface org.apache.hadoop.hbase.io.hfile.HFileScanner
-
Positions this scanner at the start of the file.
- seekToDataBlock(Cell, HFileBlock, boolean, boolean, boolean, DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
-
Return the data block which contains this key.
- seekToKeyInBlock(byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
Seek forward only (should be called reseekToKeyInBlock?).
- seekToKeyInBlock(Cell, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
- seekToKeyInBlock(byte[], int, int, boolean) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Deprecated.
- seekToKeyInBlock(Cell, boolean) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Moves the seeker position within the current block to:
the last key that that is less than or equal to the given key if
seekBefore
is false
the last key that is strictly less than the given key if
seekBefore
is true.
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
- seekToLastRow() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Seek the scanner at the first KeyValue of last row
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
-
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- seekToLastRow() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- seekToNextRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- seekToOrBeforeUsingPositionAtOrAfter(byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
- seekToOrBeforeUsingPositionAtOrAfter(Cell, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
- seekToOrBeforeUsingPositionAtOrBefore(byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
- seekToOrBeforeUsingPositionAtOrBefore(Cell, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
Separately get the KeyValue before the specified key from kvset and
snapshotset, and use the row of higher one as the previous row of
specified key, then seek to the first KeyValue of previous row
- seekToPreviousRow(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Seek the scanner at the first Cell of the row which is the previous row
of specified key
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
-
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
-
- seekToPreviousRow(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- select(List<StoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
Called to select files for compaction.
- selectCompaction(Collection<StoreFile>, List<StoreFile>, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-
- selectCompaction(StripeCompactionPolicy.StripeInformationProvider, List<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- selectFlush(StripeCompactionPolicy.StripeInformationProvider, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- SELECTOR_THREADS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Number of selector threads for reading and writing socket
- selectScannersFrom(List<? extends KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Filters the given list of scanners using Bloom filter, time range, and
TTL.
- selectSingleStripeCompaction(StripeCompactionPolicy.StripeInformationProvider, boolean, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushAllStoresPolicy
-
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushLargeStoresPolicy
-
- selectStoresToFlush() - Method in class org.apache.hadoop.hbase.regionserver.FlushPolicy
-
- selectToken(Text, Collection<Token<? extends TokenIdentifier>>) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
-
- send_append(TAppend) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_append(ByteBuffer, TAppend) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_closeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_compact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_deleteMultiple(ByteBuffer, List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_deleteSingle(ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_deleteTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_disableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_enableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_exists(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_get(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_get(ByteBuffer, TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_getColumnDescriptors(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getMultiple(ByteBuffer, List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_getRegionInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowOrBefore(ByteBuffer, ByteBuffer, ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRows(ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowsTs(ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowsWithColumns(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowsWithColumnsTs(ByteBuffer, List<ByteBuffer>, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowWithColumns(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getRowWithColumnsTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getScannerResults(ByteBuffer, TScan, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_getScannerRows(int, int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_getTableNames() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getTableRegions(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getVer(ByteBuffer, ByteBuffer, ByteBuffer, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_getVerTs(ByteBuffer, ByteBuffer, ByteBuffer, long, int, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_increment(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_increment(ByteBuffer, TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_incrementRows(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_isTableEnabled(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_majorCompact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_mutateRow(ByteBuffer, ByteBuffer, List<Mutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_mutateRow(ByteBuffer, TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_mutateRows(ByteBuffer, List<BatchMutation>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_mutateRowsTs(ByteBuffer, List<BatchMutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_mutateRowTs(ByteBuffer, ByteBuffer, List<Mutation>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_openScanner(ByteBuffer, TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_put(ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_putMultiple(ByteBuffer, List<TPut>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- send_scannerClose(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerGet(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerGetList(int, int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerOpen(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerOpenTs(ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerOpenWithPrefix(ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerOpenWithScan(ByteBuffer, TScan, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerOpenWithStop(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- send_scannerOpenWithStopTs(ByteBuffer, ByteBuffer, ByteBuffer, List<ByteBuffer>, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- sendAbortToMembers(Procedure, ForeignException) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify the members that the coordinator has aborted the procedure and that it should release
barrier resources.
- sendAbortToMembers(Procedure, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
This is the abort message being sent by the coordinator to member
TODO this code isn't actually used but can be used to issue a cancellation from the
coordinator.
- sendError(int, String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- sendError(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- sendError(int, String) - Method in interface org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter.HttpInteraction
-
Called by the filter after it decides that the request is a potential
CSRF attack and therefore must be rejected.
- sendGlobalBarrierAcquire(Procedure, byte[], List<String>) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify the members to acquire barrier for the procedure
- sendGlobalBarrierAcquire(Procedure, byte[], List<String>) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
The "acquire" phase.
- sendGlobalBarrierComplete() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- sendGlobalBarrierReached() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
Sends a message to all members that the global barrier condition has been satisfied.
- sendGlobalBarrierReached(Procedure, List<String>) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Notify members that all members have acquired their parts of the barrier and that they can
now execute under the global barrier.
- sendGlobalBarrierReached(Procedure, List<String>) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
- sendGlobalBarrierStart() - Method in class org.apache.hadoop.hbase.procedure.Procedure
-
- sendMemberAborted(Subprocedure, ForeignException) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Notify the coordinator that we aborted the specified
Subprocedure
- sendMemberAborted(Subprocedure, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
This should be called by the member and should write a serialized root cause exception as
to the abort znode.
- sendMemberAcquired(Subprocedure) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Notify the coordinator that the specified
Subprocedure
has acquired the locally required
barrier condition.
- sendMemberAcquired(Subprocedure) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
This attempts to create an acquired state znode for the procedure (snapshot name).
- sendMemberCompleted(Subprocedure, byte[]) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Notify the coordinator that the specified
Subprocedure
has completed the work that
needed to be done under the global barrier.
- sendMemberCompleted(Subprocedure, byte[]) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
This acts as the ack for a completed procedure
- sendPostSyncSignal() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- sendRedirect(String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- sendRegionClose(ServerName, HRegionInfo, int, ServerName, boolean) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends an CLOSE RPC to the specified server to close the specified region.
- sendRegionClose(ServerName, HRegionInfo, int) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- sendRegionOpen(ServerName, HRegionInfo, int, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends an OPEN RPC to the specified server to open the specified region.
- sendRegionOpen(ServerName, List<Triple<HRegionInfo, Integer, List<ServerName>>>) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends an OPEN RPC to the specified server to open the specified region.
- sendRegionsMerge(ServerName, HRegionInfo, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends an MERGE REGIONS RPC to the specified server to merge the specified
regions.
- sendRegionWarmup(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Sends a WARMUP RPC to the specified server to warmup the specified region.
- sendResponseIfReady() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
If we have a response, and delay is not set, then respond
immediately.
- sendShutdownInterrupt() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- sendShutdownInterrupt() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Called on stop/abort before closing the cluster connection and meta locator.
- SENT_BYTES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- SENT_BYTES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- sentBytes(long) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- sentBytes(long) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- separator() - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
- separator() - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- SEPARATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- SEQ_ID - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Comparators
-
Comparator that compares based on the Sequence Ids of the
the StoreFiles.
- seqids - Static variable in class org.apache.hadoop.hbase.executor.EventHandler
-
- SEQNUM_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The open seqnum column qualifier
- SEQNUM_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The open seqnum column qualifier
- SEQUENCE_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId
-
- SEQUENCE_NUMBER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
-
- SequenceFileLogReader - Class in org.apache.hadoop.hbase.regionserver.wal
-
- SequenceFileLogReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- SequenceId - Interface in org.apache.hadoop.hbase.regionserver
-
Interface which abstracts implementations on log sequenceId assignment
- sequenceID - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- sequenceIdChecker - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- sequenceNumber - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- SequentialProcedure<TEnvironment> - Class in org.apache.hadoop.hbase.procedure2
-
A SequentialProcedure describes one step in a procedure chain.
- SequentialProcedure() - Constructor for class org.apache.hadoop.hbase.procedure2.SequentialProcedure
-
- serialize(String, Throwable) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Converts a ForeignException to an array of bytes.
- serialize(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.hfile.Cacheable
-
Serializes its data into destination.
- serialize(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- serialize(KeyValue) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
-
- serialize(String, Throwable) - Static method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
-
Converts a RemoteProcedureException to an array of bytes.
- SERIALIZED_COMPARATOR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator
-
- SERIALIZED_FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter
-
- serializeExtraInfo(ByteBuffer) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
The user-level code of the procedure may have some state to
persist (e.g.
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.procedure2.SequentialProcedure
-
- serializeStateData(OutputStream) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- serve() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- server - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- server - Variable in class org.apache.hadoop.hbase.executor.EventHandler
-
- server - Variable in class org.apache.hadoop.hbase.master.AssignmentManager
-
- server - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.AssignRegionAction
-
- server - Variable in class org.apache.hadoop.hbase.master.BulkAssigner
-
- Server - Interface in org.apache.hadoop.hbase
-
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
- SERVER_CURRENT_TIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- SERVER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- SERVER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest
-
- SERVER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest
-
- SERVER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest
-
- SERVER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- SERVER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- SERVER_INFO_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse
-
- SERVER_LOAD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo
-
- SERVER_NAME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- SERVER_NAME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SERVER_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo
-
- SERVER_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition
-
- SERVER_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- SERVER_NAME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- SERVER_NAME_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SERVER_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The server column qualifier
- SERVER_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The server column qualifier
- SERVER_START_CODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest
-
- serverAdded(ServerName) - Method in interface org.apache.hadoop.hbase.master.ServerListener
-
The server has joined the cluster.
- ServerCommandLine - Class in org.apache.hadoop.hbase.util
-
Base class for command lines that start up various HBase daemons.
- ServerCommandLine() - Constructor for class org.apache.hadoop.hbase.util.ServerCommandLine
-
- ServerConfigurationKeys - Interface in org.apache.hadoop.hbase.http
-
This interface contains constants for configuration keys used
in the hbase http server code.
- serverHasMoreResults - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- serverHasMoreResultsContext - Variable in class org.apache.hadoop.hbase.client.ScannerCallable
-
- ServerListener - Interface in org.apache.hadoop.hbase.master
-
Get notification of server events.
- ServerLoad - Class in org.apache.hadoop.hbase
-
This class is used for exporting current state of load on a RegionServer.
- ServerLoad(ClusterStatusProtos.ServerLoad) - Constructor for class org.apache.hadoop.hbase.ServerLoad
-
- serverLoad - Variable in class org.apache.hadoop.hbase.ServerLoad
-
- ServerManager - Class in org.apache.hadoop.hbase.master
-
The ServerManager class manages info about region servers.
- ServerManager(Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.ServerManager
-
Constructor.
- serverManager - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- ServerMetricsTmpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- ServerMetricsTmpl(TemplateManager) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- ServerMetricsTmpl() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl
-
- ServerMetricsTmpl.ImplData - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- ServerMetricsTmpl.ImplData() - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
-
- ServerMetricsTmpl.Intf - Interface in org.apache.hadoop.hbase.tmpl.regionserver
-
- ServerMetricsTmplImpl - Class in org.apache.hadoop.hbase.tmpl.regionserver
-
- ServerMetricsTmplImpl(TemplateManager, ServerMetricsTmpl.ImplData) - Constructor for class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmplImpl
-
- serverName - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- serverName - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
The server name the Master sees us as.
- ServerName - Class in org.apache.hadoop.hbase
-
Instance of an HBase ServerName.
- serverName - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- SERVERNAME_PATTERN - Static variable in class org.apache.hadoop.hbase.ServerName
-
- SERVERNAME_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- SERVERNAME_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The serverName column qualifier.
- SERVERNAME_SEPARATOR - Static variable in class org.apache.hadoop.hbase.ServerName
-
This character is used as separator between server hostname, port and
startcode.
- ServerNonceManager - Class in org.apache.hadoop.hbase.regionserver
-
Implementation of nonce manager that stores nonces in a hash map and cleans them up after
some time; if nonce group/client ID is supplied, nonces are stored by client ID.
- ServerNonceManager(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
- ServerNotRunningYetException - Exception in org.apache.hadoop.hbase.ipc
-
- ServerNotRunningYetException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.ServerNotRunningYetException
-
- serverOffline(ZooKeeperWatcher, ServerName) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
A server is offline, all regions on it are dead.
- ServerRegionReplicaUtil - Class in org.apache.hadoop.hbase.util
-
- ServerRegionReplicaUtil() - Constructor for class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
- serverRemoved(ServerName) - Method in interface org.apache.hadoop.hbase.master.ServerListener
-
The server was removed from the cluster.
- ServerRpcController - Class in org.apache.hadoop.hbase.ipc
-
Used for server-side protobuf RPC service invocations.
- ServerRpcController() - Constructor for class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- servers - Variable in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- servers - Variable in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- ServerShutdownHandler - Class in org.apache.hadoop.hbase.master.handler
-
Process server shutdown.
- ServerShutdownHandler(Server, MasterServices, DeadServer, ServerName, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- SERVERSTARTCODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- SERVERSTARTCODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest
-
- ServerStatistics - Class in org.apache.hadoop.hbase.client.backoff
-
Track the statistics for a single region
- ServerStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics
-
- ServerStatistics.RegionStatistics - Class in org.apache.hadoop.hbase.client.backoff
-
- ServerStatistics.RegionStatistics() - Constructor for class org.apache.hadoop.hbase.client.backoff.ServerStatistics.RegionStatistics
-
- ServerStatisticTracker - Class in org.apache.hadoop.hbase.client
-
Tracks the statistics for multiple regions
- ServerStatisticTracker() - Constructor for class org.apache.hadoop.hbase.client.ServerStatisticTracker
-
- SERVERVERSION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version
-
- service - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- service - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- service(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.rest.RESTServletContainer
-
This container is used only if authentication and
impersonation is enabled.
- SERVICE_CALL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action
-
- SERVICE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token
-
- SERVICE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
-
- SERVICE_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall
-
- SERVICE_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader
-
- SERVICE_RESULT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException
-
- services - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- services - Variable in class org.apache.hadoop.hbase.master.handler.LogReplayHandler
-
- services - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- services - Variable in class org.apache.hadoop.hbase.regionserver.LogRoller
-
- services - Static variable in class org.apache.hadoop.hbase.security.HBasePolicyProvider
-
- set(TokenizerRowSearchPosition, TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
-
- set(String, String) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.ImmutableBytesWritable
-
- set(long, TimeUnit) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
Set the RateLimiter max available resources and refill period.
- set(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- set(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- set(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Reuse this ByteRange
over a new byte[].
- set(byte[]) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Reuse this ByteRange
over a new byte[].
- set(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Reuse this ByteRange
over a new byte[].
- set(long) - Method in class org.apache.hadoop.hbase.util.Counter
-
- set(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- set(byte[]) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- set(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- set(int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- set(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- set(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- set(byte[]) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- set(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- setAbortFailure(String, String) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Append
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Append
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Get
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Get
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Put
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Put
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Query
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Query
-
- setACL(Map<String, Permission>) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setACL(String, Permission) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setACL(AccessControlList) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setAcl(String, List<ACL>, int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
setAcl is an idempotent operation.
- setAction(int, AccessControlProtos.Permission.Action) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
repeated .Permission.Action action = 1;
- setAction(int, AccessControlProtos.Permission.Action) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
repeated .Permission.Action action = 2;
- setAction(int, AccessControlProtos.Permission.Action) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
repeated .Permission.Action action = 4;
- setAction(int, ClientProtos.Action) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- setAction(int, ClientProtos.Action.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- setAction(WALProtos.FlushDescriptor.FlushAction) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
required .FlushDescriptor.FlushAction action = 1;
- setAgeOfLastAppliedOp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
required uint64 ageOfLastAppliedOp = 1;
- setAgeOfLastAppliedOp(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Set the age of the last applied operation
- setAgeOfLastShippedOp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint64 ageOfLastShippedOp = 2;
- setAgeOfLastShippedOp(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Set the age of the last edit that was shipped
- setAlgorithm(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required string algorithm = 1;
- setAlgorithmBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required string algorithm = 1;
- setAllowed(boolean) - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- setAllowPartialResults(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Setting whether the caller wants to see the partial results that may be returned from the
server.
- setAllowPartialResults(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool allow_partial_results = 18;
- setAllSameType(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setAllSameType(boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setAllTypes(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setAmmount(long) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setAmmountIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setAmount(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setAmountIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setAppDir(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setAppend(TAppend) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
The single append operation to apply
- setAppend(TAppend) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
the TAppend to append
- setAppendIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
- setAppendIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
- setArchiveTables(List<String>) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
Set the tables to be archived.
- setArrayOffset(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setAssignmentManager(AssignmentManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setAssignSeqNum(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
optional bool assign_seq_num = 3;
- setAssignSeqNum(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
optional bool assign_seq_num = 2;
- setAssociatedCellCount(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
optional int32 associated_cell_count = 3;
- setAssociatedCellCount(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional int32 associated_cell_count = 8;
- setAssociatedCellCount(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional int32 associated_cell_count = 2;
- setAtomic(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
optional bool atomic = 2;
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Append
-
- setAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.client.Attributes
-
Sets an attribute.
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Get
-
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
- setAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setAttribute(String, Object) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Set a value in the webapp context.
- setAttribute(String, Object) - Method in class org.apache.hadoop.hbase.http.InfoServer
-
- setAttribute(int, HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- setAttribute(int, HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- setAttribute(int, HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- setAttribute(int, HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- setAttribute(int, HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- setAttribute(int, HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- setAttributes(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- setAttributes(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- setAttributes(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- setAttributes(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
Mutation attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Delete attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Delete attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Delete attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Delete attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Get attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Mutation attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
Mutation attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Mutation attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Mutation attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Scan attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Scan attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Scan attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Scan attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Scan attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Scan attributes
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setAttributes(Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setAttributesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- setAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- setAttrs(int, TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- setAttrs(int, TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- setAuth(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
repeated bytes auth = 2;
- setAuth(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
repeated bytes auth = 2;
- setAuth(int, int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
repeated uint32 auth = 2;
- setAuthMethod(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
optional string auth_method = 2;
- setAuthMethodBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
optional string auth_method = 2;
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Get
-
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Query
-
Sets the authorizations to be used by this Query
- setAuthorizations(Authorizations) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setAuthorizations(TAuthorization) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setAuthorizations(TAuthorization) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setAuthorizationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setAuthorizationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.BlockingInterface
-
- setAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.Interface
-
rpc setAuths(.SetAuthsRequest) returns (.VisibilityLabelsResponse);
- setAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService
-
rpc setAuths(.SetAuthsRequest) returns (.VisibilityLabelsResponse);
- setAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.Stub
-
- setAuths(byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- setAuths(Configuration, String[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Sets given labels globally authorized for the user.
- setAuths(RpcController, VisibilityLabelsProtos.SetAuthsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- setAuths(byte[], List<byte[]>) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Sets given labels globally authorized for the user.
- setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
- setAutoFlush(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Turns 'auto-flush' on or off.
- setAutoFlush(boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
Deprecated.
in 0.96. When called with setAutoFlush(false), this function also
set clearBufferOnFail to true, which is unexpected but kept for historical reasons.
Replace it with setAutoFlush(false, false) if this is exactly what you want, though
this is the method you want for most cases.
- setAutoFlush(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- setAutoFlush(boolean) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- setAutoFlush(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- setAutoFlushTo(boolean) - Method in class org.apache.hadoop.hbase.client.HTable
-
Set the autoFlush behavior, without changing the value of clearBufferOnFail
.
- setAutoFlushTo(boolean) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- setAutoFlushTo(boolean) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- setAverageLoad(double) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setAverageLoad(double) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
optional double averageLoad = 5;
- setAveragePrefixLength(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setAverageQualifierLength(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setAverageSuffixLength(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setBackoffPolicy(RetryCounter.BackoffPolicy) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- setBackupMasters(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- setBackupMasters(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- setBalancerOn(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional bool balancer_on = 9;
- setBalancerOn(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState.Builder
-
optional bool balancer_on = 1;
- setBalancerOn(boolean) - Method in class org.apache.hadoop.hbase.zookeeper.LoadBalancerTracker
-
Set the balancer on/off
- setBalancerRan(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.BalanceResponse.Builder
-
required bool balancer_ran = 1;
- setBalancerRunning(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Turn the load balancer on or off.
- setBalancerRunning(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Turn the load balancer on or off.
- setBalancerRunning(RpcController, MasterProtos.SetBalancerRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- setBalancerRunning(RpcController, MasterProtos.SetBalancerRunningRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- setBalancerRunning(RpcController, MasterProtos.SetBalancerRunningRequest, RpcCallback<MasterProtos.SetBalancerRunningResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc SetBalancerRunning(.SetBalancerRunningRequest) returns (.SetBalancerRunningResponse);
- setBalancerRunning(RpcController, MasterProtos.SetBalancerRunningRequest, RpcCallback<MasterProtos.SetBalancerRunningResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc SetBalancerRunning(.SetBalancerRunningRequest) returns (.SetBalancerRunningResponse);
- setBalancerRunning(RpcController, MasterProtos.SetBalancerRunningRequest, RpcCallback<MasterProtos.SetBalancerRunningResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- setBaseTimestampDivide(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setBatch(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum number of values to return for each call to next().
- setBatch(int) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setBatch(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int32 batch = 4;
- setBatchLimit(int) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
-
- setBatchSize(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 batch_size = 9;
- setBatchSize(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setBatchSize(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setBatchSizeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setBatchSizeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setBcn(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- setBcn(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setBcn(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- setBcv(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- setBcv(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setBcv(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- setBigdecimalMsg(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BigDecimalMsg.Builder
-
required bytes bigdecimal_msg = 1;
- setBindAddress(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Deprecated.
- setBitwiseOp(ComparatorProtos.BitComparator.BitwiseOp) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
required .BitComparator.BitwiseOp bitwise_op = 2;
- setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setBlockCacheEnabled(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBlockCacheEnabledIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBlockCacheSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- setBlockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setBlocksize(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setBloomFilterNbHashes(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBloomFilterNbHashesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBloomFilterType(BloomType) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setBloomFilterType(String) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBloomFilterTypeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBloomFilterVectorSize(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBloomFilterVectorSizeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setBody(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- setBufferOffset(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setBuilder(Tokenizer) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- setBulkLoaded(boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- setBulkloadSeqNum(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required int64 bulkload_seq_num = 4;
- setBulkToken(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
required string bulk_token = 1;
- setBulkToken(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
required string bulk_token = 1;
- setBulkToken(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required string bulk_token = 4;
- setBulkTokenBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.CleanupBulkLoadRequest.Builder
-
required string bulk_token = 1;
- setBulkTokenBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadResponse.Builder
-
required string bulk_token = 1;
- setBulkTokenBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required string bulk_token = 4;
- setBypassGlobals(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional bool bypass_globals = 6;
- setBypassGlobals(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
optional bool bypass_globals = 1 [default = false];
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
Set whether blocks should be cached for this Get.
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether blocks should be cached for this Scan.
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional bool cache_blocks = 7 [default = true];
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool cache_blocks = 8 [default = true];
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setCacheBlocks(boolean) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional bool cacheBlocks = 11;
- setCacheBloomsOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCacheConfig(CacheConfig) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
-
- setCacheConfig(CacheConfig) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- setCacheDataInL1(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCacheDataInL1(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Only used for testing.
- setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCacheDataOnWrite(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Only used for testing.
- setCacheIndexesOnWrite(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setCacheOff() - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Disables the tabledescriptor cache
- setCacheOff() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- setCacheOn() - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Enables the tabledescriptor cache
- setCacheOn() - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the number of rows for caching that will be passed to scanners.
- setCaching(int) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Set the number of rows that will be fetched on next
- setCaching(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 caching = 17;
- setCaching(int) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setCaching(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int32 caching = 9;
- setCaching(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setCaching(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setCachingIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setCachingIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setCall(ClientProtos.CoprocessorServiceCall) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .CoprocessorServiceCall call = 2;
- setCall(ClientProtos.CoprocessorServiceCall.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .CoprocessorServiceCall call = 2;
- setCallId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional uint32 call_id = 1;
- setCallId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional uint32 call_id = 1;
- setCallQueueLen(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
Set the call queue length.
- setCallQueueLen(int) - Method in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
-
- setCallQueueLen(int) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- setCallTimeout(int) - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
-
- setCatalogJanitorEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
Switch for the background CatalogJanitor thread.
- setCatalogJanitorEnabled(boolean) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setCatalogJanitorEnabled(boolean) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setCell(int, CellProtos.Cell) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- setCell(int, CellProtos.Cell.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- setCell(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- setCellBlockCodecClass(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string cell_block_codec_class = 3;
- setCellBlockCodecClassBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string cell_block_codec_class = 3;
- setCellBlockCompressorClass(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string cell_block_compressor_class = 4;
- setCellBlockCompressorClassBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string cell_block_compressor_class = 4;
- setCellBlockMeta(RPCProtos.CellBlockMeta) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 5;
- setCellBlockMeta(RPCProtos.CellBlockMeta.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 5;
- setCellBlockMeta(RPCProtos.CellBlockMeta) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 3;
- setCellBlockMeta(RPCProtos.CellBlockMeta.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .CellBlockMeta cell_block_meta = 3;
- setCellCodecClsName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional string cell_codec_cls_name = 5;
- setCellCodecClsNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional string cell_codec_cls_name = 5;
- setCellIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
-
- setCellScanner(CellScanner) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- setCellsPerResult(int, int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated uint32 cells_per_result = 1;
- setCellType(CellProtos.CellType) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional .CellType cell_type = 5;
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Append
-
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Sets the visibility expression associated with cells in this Mutation.
- setCellVisibility(CellVisibility) - Method in class org.apache.hadoop.hbase.client.Put
-
- setCellVisibility(TCellVisibility) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- setCellVisibility(TCellVisibility) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setCellVisibility(TCellVisibility) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setCellVisibilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- setCellVisibilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setCellVisibilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setChance(float) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
-
Set the chance that a row is included.
- setChance(float) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RandomRowFilter.Builder
-
required float chance = 1;
- setChanceForSameQualifier(float) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setChanceForSimilarQualifier(float) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setChanceForZeroValue(float) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setCharset(Charset) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
-
Specifies the
Charset
to use to convert the row key to a String.
- setCharset(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required string charset = 3;
- setCharsetBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required string charset = 3;
- setCheckExistenceOnly(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
- setCheckHdfs(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setChildrenLatch(int) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor on procedure-load to restore the latch state
- setCipher(Cipher) - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- setCipher(Cipher) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
-
- setClassName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional string class_name = 1;
- setClassName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required string class_name = 1;
- setClassNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional string class_name = 1;
- setClassNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required string class_name = 1;
- setClientAckTime(long) - Method in class org.apache.hadoop.hbase.ProcedureInfo
-
- setClientHandlesHeartbeats(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool client_handles_heartbeats = 8;
- setClientHandlesPartials(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool client_handles_partials = 7;
- setClose() - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Call this when the next invocation of call should close the scanner
- setClosed(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionResponse.Builder
-
required bool closed = 1;
- setClosedState(HRegion, ServerName, CloseRegionCoordination.CloseRegionDetails) - Method in interface org.apache.hadoop.hbase.coordination.CloseRegionCoordination
-
Called after region is closed to notify all interesting parties / "register"
region as finally closed.
- setClosedState(HRegion, ServerName, CloseRegionCoordination.CloseRegionDetails) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination
-
In ZK-based version we do some znodes transitioning.
- setCloseScanner(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool close_scanner = 5;
- setClosestRowBefore(boolean) - Method in class org.apache.hadoop.hbase.client.Get
-
- setClosestRowBefore(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional bool closest_row_before = 11 [default = false];
- setClosing(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Exposed for some very specific unit tests.
- setCluster(Cluster) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
- setClusterDown() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Sets the cluster as down by deleting the znode.
- setClusterId(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
required string cluster_id = 1;
- setClusterId(ClusterIdProtos.ClusterId) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ClusterId cluster_id = 5;
- setClusterId(ClusterIdProtos.ClusterId.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ClusterId cluster_id = 5;
- setClusterId(HBaseProtos.UUID) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
Deprecated.
- setClusterId(HBaseProtos.UUID.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
Deprecated.
- setClusterId(FileSystem, Path, ClusterId, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Writes a new unique identifier for this cluster to the "hbase.id" file
in the HBase root directory
- setClusterId(ZooKeeperWatcher, ClusterId) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
-
- setClusterIdBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterIdProtos.ClusterId.Builder
-
required string cluster_id = 1;
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Append
-
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Marks that the clusters with the given clusterIds have consumed the mutation
- setClusterIds(List<UUID>) - Method in class org.apache.hadoop.hbase.client.Put
-
- setClusterIds(int, HBaseProtos.UUID) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- setClusterIds(int, HBaseProtos.UUID.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- setClusterkey(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
required string clusterkey = 1;
- setClusterKey(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
Set the clusterKey which is the concatenation of the slave cluster's:
hbase.zookeeper.quorum:hbase.zookeeper.property.clientPort:zookeeper.znode.parent
- setClusterkeyBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
required string clusterkey = 1;
- setClusterStatus(ClusterStatus) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- setClusterStatus(ClusterStatus) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- setClusterStatus(ClusterStatus) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Set the current cluster status.
- setClusterStatus(ClusterStatusProtos.ClusterStatus) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
required .ClusterStatus cluster_status = 1;
- setClusterStatus(ClusterStatusProtos.ClusterStatus.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetClusterStatusResponse.Builder
-
required .ClusterStatus cluster_status = 1;
- setClusterUp() - Method in class org.apache.hadoop.hbase.zookeeper.ClusterStatusTracker
-
Sets the cluster as up.
- setCode(int) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- setColumn(int, ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- setColumn(int, ClientProtos.Column.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- setColumn(int, ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- setColumn(int, ClientProtos.Column.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- setColumn(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional bytes column = 2;
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
name of column
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
column name
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
name of column whose value is to be deleted
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
name of column whose value is to be deleted
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
column name
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
column name
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
column name
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setColumn(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setColumn(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setColumnFamilies(int, HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- setColumnFamilies(int, HBaseProtos.ColumnFamilySchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- setColumnFamilies(HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- setColumnFamilies(HBaseProtos.ColumnFamilySchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- setColumnFamilies(HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- setColumnFamilies(HBaseProtos.ColumnFamilySchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .ColumnFamilySchema column_families = 2;
- setColumnFamilies(List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
list of column family descriptors
- setColumnFamiliesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- setColumnFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
optional bytes column_family = 2;
- setColumnFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bytes column_family = 1;
- setColumnFamilyLength(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setColumnfamilyName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required bytes columnfamily_name = 3;
- setColumnfamilySchema(HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- setColumnfamilySchema(HBaseProtos.ColumnFamilySchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- setColumnfamilySchema(HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- setColumnfamilySchema(HBaseProtos.ColumnFamilySchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .ColumnFamilySchema columnfamily_schema = 3;
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setColumnIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setColumnName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
required bytes column_name = 2;
- setColumnName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- setColumnName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- setColumnNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- setColumnOffset(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
optional bytes column_offset = 3;
- setColumnQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
optional bytes column_qualifier = 3;
- setColumnQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bytes column_qualifier = 2;
- setColumns(List<byte[]>) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setColumns(List<ColumnSchemaModel>) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- setColumns(int, ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated bytes columns = 3;
- setColumns(int, ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- setColumns(int, ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
List of columns to return, null for all columns
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
List of columns to return, null for all columns
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
List of columns to return, null for all columns
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
List of columns to return, null for all columns
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
columns to scan.
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
columns to scan.
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
the columns you want returned
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
columns to scan.
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
columns to scan.
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- setColumns(Map<ByteBuffer, TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setColumns(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setColumns(List<TColumnValue>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- setColumns(List<TColumn>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setColumns(List<TColumn>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setColumns(List<TColumnIncrement>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setColumns(List<TColumn>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setColumnValue(int, ClientProtos.MutationProto.ColumnValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- setColumnValue(int, ClientProtos.MutationProto.ColumnValue.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- setColumnValues(List<TColumnValue>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setColumnValues(List<TColumnValue>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- setColumnValuesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setColumnValuesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- setCommonPrefix(byte[]) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
get/set
- setCompactionCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Compression types supported in hbase.
- setCompactionEnabled(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Setting the table compaction enable flag.
- setCompactionInput(int, String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_input = 4;
- setCompactionOutput(int, String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_output = 5;
- setCompactionState(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
optional bool compaction_state = 2;
- setCompactionState(AdminProtos.GetRegionInfoResponse.CompactionState) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
optional .GetRegionInfoResponse.CompactionState compaction_state = 2;
- setCompactionTimestamp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampResponse.Builder
-
required int64 compaction_timestamp = 1;
- setComparable(ComparatorProtos.ByteArrayComparable) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- setComparable(ComparatorProtos.ByteArrayComparable.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- setComparable(ComparatorProtos.ByteArrayComparable) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- setComparable(ComparatorProtos.ByteArrayComparable.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BinaryPrefixComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- setComparable(ComparatorProtos.ByteArrayComparable) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- setComparable(ComparatorProtos.ByteArrayComparable.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- setComparable(ComparatorProtos.ByteArrayComparable) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- setComparable(ComparatorProtos.ByteArrayComparable.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.LongComparator.Builder
-
required .ByteArrayComparable comparable = 1;
- setComparator(ComparatorProtos.Comparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required .Comparator comparator = 5;
- setComparator(ComparatorProtos.Comparator.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required .Comparator comparator = 5;
- setComparator(ComparatorProtos.Comparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
optional .Comparator comparator = 2;
- setComparator(ComparatorProtos.Comparator.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
optional .Comparator comparator = 2;
- setComparator(ComparatorProtos.Comparator) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
required .Comparator comparator = 4;
- setComparator(ComparatorProtos.Comparator.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
required .Comparator comparator = 4;
- setComparatorClass(Class<? extends KeyValue.KVComparator>) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setComparatorClassName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional string comparator_class_name = 11;
- setComparatorClassNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional string comparator_class_name = 11;
- setCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
required .CompareFilter compare_filter = 1;
- setCompareFilter(FilterProtos.CompareFilter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
required .CompareFilter compare_filter = 1;
- setCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
required .CompareFilter compare_filter = 1;
- setCompareFilter(FilterProtos.CompareFilter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FamilyFilter.Builder
-
required .CompareFilter compare_filter = 1;
- setCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
required .CompareFilter compare_filter = 1;
- setCompareFilter(FilterProtos.CompareFilter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.QualifierFilter.Builder
-
required .CompareFilter compare_filter = 1;
- setCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
required .CompareFilter compare_filter = 1;
- setCompareFilter(FilterProtos.CompareFilter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowFilter.Builder
-
required .CompareFilter compare_filter = 1;
- setCompareFilter(FilterProtos.CompareFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
required .CompareFilter compare_filter = 1;
- setCompareFilter(FilterProtos.CompareFilter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ValueFilter.Builder
-
required .CompareFilter compare_filter = 1;
- setCompareOp(HBaseProtos.CompareType) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.CompareFilter.Builder
-
required .CompareType compare_op = 1;
- setCompareOp(HBaseProtos.CompareType) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
required .CompareType compare_op = 3;
- setCompareType(HBaseProtos.CompareType) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required .CompareType compare_type = 4;
- setCompleteSequenceId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 complete_sequence_id = 15;
- setCompression(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- setCompression(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional string compression = 5;
- setCompression(String) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setCompressionBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional string compression = 5;
- setCompressionCodec(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setCompressionCodec(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 compression_codec = 12;
- setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.wal.WAL.Entry
-
Set compression context for this entry.
- setCompressionContext(CompressionContext) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- setCompressionIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setCompressionType(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Compression types supported in hbase.
- setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set whether the tags should be compressed along with DataBlockEncoding.
- setCompressTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- setCondition(ClientProtos.Condition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
optional .Condition condition = 3;
- setCondition(ClientProtos.Condition.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
optional .Condition condition = 3;
- setCondition(ClientProtos.Condition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
optional .Condition condition = 3;
- setCondition(ClientProtos.Condition.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
optional .Condition condition = 3;
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.BaseConfigurable
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.crypto.DefaultCipherProvider
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.HRegionPartitioner
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormat
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Sets the configuration.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputFormat
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredNodeLoadBalancer
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
This method should only be called once, as it starts a thread to keep the cache
up-to-date.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
Inform the policy that some configuration has been change,
so cached value should be updated it any.
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.NoOpHeapMemoryTuner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionFactory
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- setConf(Configuration, ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.EnforcingScanLabelGenerator
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.FeedUserAuthScanLabelGenerator
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheViewTmpl.ImplData
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.tool.Canary
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- setConf(Configuration) - Method in class org.apache.hadoop.hbase.util.MapreduceDependencyClasspathTool
-
- setConfig(Configuration) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.BlockCacheTmpl.ImplData
-
- setConfiguration(HTableDescriptor, Class<? extends Constraint>, Configuration) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Update the configuration for the
Constraint
; does not change the
order in which the constraint is run.
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- setConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- setConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- setConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- setConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- setConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- setConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- setConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- setConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- setConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- setConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- setConfigure(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp
-
- setConflictWaitIterationMs(int) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
- setConnection(String, int) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- setConnection(String, int) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Registers current handler client details.
- setConnector(Connector) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Get
-
- setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Query
-
Sets the consistency level for this operation
- setConsistency(Consistency) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setConsistency(ClientProtos.Consistency) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .Consistency consistency = 12 [default = STRONG];
- setConsistency(ClientProtos.Consistency) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .Consistency consistency = 16 [default = STRONG];
- setContentLength(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- setContext(HRegion.RowLockContext) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.RowLockImpl
-
- setContext(String) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Set the metrics context tag
- setControllerException(RpcController, IOException) - Static method in class org.apache.hadoop.hbase.protobuf.ResponseConverter
-
Stores an exception encountered during RPC invocation so it can be passed back
through to the client.
- setCoprocessorHost(RegionCoprocessorHost) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setCoprocessors(int, HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- setCoprocessors(int, HBaseProtos.Coprocessor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- setCorePoolSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- setCorePoolSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- setCount(long) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse.Builder
-
required int64 count = 1 [default = 0];
- setCount(int) - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Set the current count to a new count
- setCounter(String, long) - Method in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
- setCreateTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required uint64 create_time = 3;
- setCreateTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional int64 create_time = 6;
- setCreationTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
optional int64 creation_time = 3 [default = 0];
- setCreationTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional int64 creation_time = 3 [default = 0];
- setCurBlockCacheSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setCurMemStoreSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setCurrentBuffer(ByteBuffer) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
- setCurrentBuffer(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder.EncodedSeeker
-
Set on which buffer there will be done seeking.
- setCurrentCell(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- setCurrentCompactedKVs(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 current_compacted_KVs = 11;
- setCurrentCompactedKVs(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setCurrentCompactedKVs(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 currentCompactedKVs = 13;
- setCurTaskZKVersion(MutableInt) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- setDaemon(boolean) - Method in class org.apache.hadoop.hbase.util.HasThread
-
- setDaemonThreadRunning(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Utility method that sets name, daemon status and starts passed thread.
- setDaemonThreadRunning(Thread, String) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Utility method that sets name, daemon status and starts passed thread.
- setDaemonThreadRunning(Thread, String, Thread.UncaughtExceptionHandler) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Utility method that sets name, daemon status and starts passed thread.
- setData(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required bytes data = 3;
- setData(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- setData(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- setData(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional bytes data = 4;
- setData(String, byte[], int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
setData is NOT an idempotent operation.
- setData(ZooKeeperWatcher, String, byte[], int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Sets the data of the existing znode to be the specified data.
- setData(ZooKeeperWatcher, String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Sets the data of the existing znode to be the specified data.
- setData(String, byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set data block encoding algorithm used in block cache.
- setDataBlockEncoding(DataBlockEncoding) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- setDataIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setDataIndexCount(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 data_index_count = 5;
- setDataLocality(float) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional float data_locality = 16;
- setDate(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string date = 5;
- setDateBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string date = 5;
- setDeadNodes(List<String>) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setDeadNodes(int, String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated string deadNodes = 2;
- setDeadServers(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- setDeadServers(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- setDeadServers(Set<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setDeadServers(Set<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setDeclaringClass(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string declaring_class = 1;
- setDeclaringClassBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string declaring_class = 1;
- setDefaultClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- setDeleteColumnFamilyInModify(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required bool delete_column_family_in_modify = 4;
- setDeleted(long, boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- setDeleted(int, long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 deleted = 3;
- setDeletedTable(TableName) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
Mark table as deleted.
- setDeletedTable(TableName) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Deletes the table in zookeeper.
- setDeleteFamilyBloomFilterFaulty() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- setDeletes(List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
list of TDeletes to delete
- setDeleteSingle(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
the TDelete to execute if the check succeeds
- setDeleteSingle(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
the TDelete to delete
- setDeleteSingle(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- setDeleteSingleIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setDeleteSingleIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- setDeletesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- setDeleteType(BulkDeleteProtos.BulkDeleteRequest.DeleteType) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required .BulkDeleteRequest.DeleteType deleteType = 2;
- setDeleteType(ClientProtos.MutationProto.DeleteType) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional .MutationProto.DeleteType delete_type = 4;
- setDeleteType(TDeleteType) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setDeleteTypeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setDescription(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- setDescription(String, String) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Sets the region/store name, for logging.
- setDestination(ServerName) - Method in class org.apache.hadoop.hbase.master.RegionPlan
-
Set the destination server for the plan for this region.
- setDestinationServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional .ServerName destination_server = 4;
- setDestinationServer(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional .ServerName destination_server = 4;
- setDestServerName(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
optional .ServerName dest_server_name = 2;
- setDestServerName(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
optional .ServerName dest_server_name = 2;
- setDetails(SplitLogManagerCoordination.SplitLogManagerDetails) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Provide the configuration from the SplitLogManager
- setDetails(SplitLogManagerCoordination.SplitLogManagerDetails) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- setDisplayFullReport() - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Display the full report from fsck.
- setDone(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
optional bool done = 1 [default = false];
- setDone(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse.Builder
-
optional bool done = 1 [default = false];
- setDone(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
optional bool done = 1 [default = false];
- setDoNotRetry(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional bool do_not_retry = 5;
- setDoubleMsg(double) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg.Builder
-
required double double_msg = 1;
- setDropDependentColumn(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter.Builder
-
optional bool drop_dependent_column = 4;
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Append
-
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the durability for this mutation
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.client.Put
-
- setDurability(Durability) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setDurability(ClientProtos.MutationProto.Durability) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .MutationProto.Durability durability = 6 [default = USE_DEFAULT];
- setDurability(TDurability) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- setDurability(TDurability) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setDurability(TDurability) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setDurability(TDurability) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setDurabilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- setDurabilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setDurabilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setDurabilityIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setEffectiveUser(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
required string effective_user = 1;
- setEffectiveUser(String) - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Set the current thread local effective user
- setEffectiveUserBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
required string effective_user = 1;
- setEnable(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorRequest.Builder
-
required bool enable = 1;
- setEnabled(boolean) - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
-
- setEnabled(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsBalancerEnabledResponse.Builder
-
required bool enabled = 1;
- setEnabledTable(TableName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- setEncodedRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required bytes encoded_region_name = 2;
- setEncodedRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required bytes encoded_region_name = 2;
- setEncodedRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
required bytes encoded_region_name = 3;
- setEncodedRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
required bytes encoded_region_name = 3;
- setEncodedRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required bytes encoded_region_name = 1;
- setEncodeOnDisk(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Deprecated.
As of release 0.98
(HBASE-9870).
This will be removed in HBase 2.0.0. This method does nothing now.
- setEncodingState(EncodingState) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- setEncodingState(EncodingState) - Method in interface org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext
-
Sets the encoding state.
- setEncryptionContext(Encryption.Context) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set the raw crypto key attribute for the family
- setEncryptionKey(byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setEncryptionKey(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional bytes encryption_key = 13;
- setEncryptionKey(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional bytes encryption_key = 2;
- setEncryptionType(String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
Set the encryption algorithm for use with this family
- setEndKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- setEndKey(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bytes end_key = 4;
- setEndKey(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setEndKey(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional bytes endKey = 3;
- setEndKey(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setEndKey(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setEndKeyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setEndRow(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setEndRow(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional bytes endRow = 2;
- setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int64 endTime = 6;
- setEndTime(long) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- setEngine(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
optional string engine = 4;
- setEngineBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
optional string engine = 4;
- setEntries(List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- setEntry(int, AdminProtos.WALEntry) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- setEntry(int, AdminProtos.WALEntry.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- setEntryCount(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setEntryCount(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 entry_count = 7;
- setErr(Throwable) - Method in class org.apache.hadoop.hbase.regionserver.handler.ParallelSeekHandler
-
- setErrorHandler(HBaseRPCErrorHandler) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Set the handler for calling out of RPC for error conditions.
- setErrorHandler(HBaseRPCErrorHandler) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- setErrorInfo(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional bytes error_info = 3;
- setErrorMessage(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
optional string error_message = 1;
- setErrorMessage(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required string error_message = 2;
- setErrorMessageBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionResponse.Builder
-
optional string error_message = 1;
- setErrorMessageBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required string error_message = 2;
- setEventType(WALProtos.RegionEventDescriptor.EventType) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
required .RegionEventDescriptor.EventType event_type = 1;
- setEventTypeCode(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required uint32 event_type_code = 1;
- setEvictBlocksOnClose(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setEvictCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setEvictOnClose(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Only used for testing.
- setException(IOException) - Method in class org.apache.hadoop.hbase.ipc.Call
-
Set the exception when there is an error.
- setException(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
optional .NameBytesPair exception = 2;
- setException(HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
optional .NameBytesPair exception = 2;
- setException(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .NameBytesPair exception = 3;
- setException(HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .NameBytesPair exception = 3;
- setException(ErrorHandlingProtos.ForeignExceptionMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional .ForeignExceptionMessage exception = 5;
- setException(ErrorHandlingProtos.ForeignExceptionMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional .ForeignExceptionMessage exception = 5;
- setException(ErrorHandlingProtos.ForeignExceptionMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional .ForeignExceptionMessage exception = 10;
- setException(ErrorHandlingProtos.ForeignExceptionMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional .ForeignExceptionMessage exception = 10;
- setException(RPCProtos.ExceptionResponse) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .ExceptionResponse exception = 2;
- setException(RPCProtos.ExceptionResponse.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ResponseHeader.Builder
-
optional .ExceptionResponse exception = 2;
- setExceptionClassName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string exception_class_name = 1;
- setExceptionClassNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string exception_class_name = 1;
- setExecuted(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.SequentialProcedureData.Builder
-
required bool executed = 1;
- setExist(AlreadyExists) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setExistenceOnly(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional bool existence_only = 10 [default = false];
- setExistIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setExists(Boolean) - Method in class org.apache.hadoop.hbase.client.Result
-
- setExists(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional bool exists = 3;
- setExpectedTimeout(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
optional int64 expected_timeout = 1;
- setExpectedTimeout(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotResponse.Builder
-
required int64 expected_timeout = 1;
- setExpectedVersion(int) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
-
- setExpiration(long) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- setExpirationDate(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
required int64 expiration_date = 2;
- setExpirationDate(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
optional int64 expiration_date = 5;
- setExpression(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
required string expression = 1;
- setExpression(String) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
-
- setExpressionBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CellVisibility.Builder
-
required string expression = 1;
- setExpressionIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
-
- setFailed(IOException) - Method in class org.apache.hadoop.hbase.ipc.AsyncCall
-
Set failed
- setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- setFailed(String) - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
-
- setFailed(IOException) - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
-
Set failed with an exception to pass on.
- setFailedOn(IOException) - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
Sets an exception to be communicated back to the Service
client.
- setFailure(String, Throwable) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setFailure(RemoteProcedureException) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setFakeLookupMode(boolean) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- setFamilies(Map<byte[], ? extends Collection<?>>) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional bytes family = 2;
- setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
optional bytes family = 3;
- setFamily(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
repeated bytes family = 2;
- setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes family = 2;
- setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
required bytes family = 2;
- setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
required bytes family = 1;
- setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
required bytes family = 1;
- setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required bytes family = 2;
- setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
required bytes family = 1;
- setFamily(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
required bytes family = 1;
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
column name
- setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
column family to check
- setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
column family to check
- setFamily(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setFamily(byte[]) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Append
-
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Method for setting the put's familyMap
- setFamilyCellMap(NavigableMap<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.client.Put
-
- setFamilyFiles(int, SnapshotProtos.SnapshotRegionManifest.FamilyFiles) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- setFamilyFiles(int, SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setFamilyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Append
-
Deprecated.
- setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Delete
-
Deprecated.
- setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Increment
-
Deprecated.
- setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setFamilyMap(NavigableMap<byte[], List<KeyValue>>) - Method in class org.apache.hadoop.hbase.client.Put
-
Deprecated.
- setFamilyMap(Map<byte[], NavigableSet<byte[]>>) - Method in class org.apache.hadoop.hbase.client.Scan
-
Setting the familyMap
- setFamilyName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
required bytes family_name = 1;
- setFamilyName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
required bytes family_name = 1;
- setFamilyName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required bytes family_name = 3;
- setFamilyName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
required bytes family_name = 1;
- setFamilyName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
required bytes family_name = 1;
- setFamilyOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- setFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- setFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- setFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- setFanIndex(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.row.RowNodeReader
-
- setFavoredNode(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- setFavoredNode(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- setFavoredNodes(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- setFavoredNodes(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- setFavoredNodes(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- setFavoredNodes(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- setFieldValue(AlreadyExists._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- setFieldValue(BatchMutation._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- setFieldValue(ColumnDescriptor._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setFieldValue(Hbase.append_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
- setFieldValue(Hbase.append_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- setFieldValue(Hbase.atomicIncrement_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setFieldValue(Hbase.atomicIncrement_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setFieldValue(Hbase.checkAndPut_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- setFieldValue(Hbase.checkAndPut_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- setFieldValue(Hbase.compact_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- setFieldValue(Hbase.compact_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- setFieldValue(Hbase.createTable_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- setFieldValue(Hbase.createTable_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setFieldValue(Hbase.deleteAll_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setFieldValue(Hbase.deleteAll_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- setFieldValue(Hbase.deleteAllRow_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- setFieldValue(Hbase.deleteAllRow_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- setFieldValue(Hbase.deleteAllRowTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setFieldValue(Hbase.deleteAllRowTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- setFieldValue(Hbase.deleteAllTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setFieldValue(Hbase.deleteAllTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- setFieldValue(Hbase.deleteTable_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- setFieldValue(Hbase.deleteTable_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- setFieldValue(Hbase.disableTable_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- setFieldValue(Hbase.disableTable_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- setFieldValue(Hbase.enableTable_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- setFieldValue(Hbase.enableTable_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- setFieldValue(Hbase.get_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setFieldValue(Hbase.get_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- setFieldValue(Hbase.getColumnDescriptors_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- setFieldValue(Hbase.getColumnDescriptors_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- setFieldValue(Hbase.getRegionInfo_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- setFieldValue(Hbase.getRegionInfo_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- setFieldValue(Hbase.getRow_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- setFieldValue(Hbase.getRow_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- setFieldValue(Hbase.getRowOrBefore_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setFieldValue(Hbase.getRowOrBefore_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- setFieldValue(Hbase.getRows_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- setFieldValue(Hbase.getRows_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- setFieldValue(Hbase.getRowsTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- setFieldValue(Hbase.getRowsTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- setFieldValue(Hbase.getRowsWithColumns_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- setFieldValue(Hbase.getRowsWithColumns_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- setFieldValue(Hbase.getRowsWithColumnsTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setFieldValue(Hbase.getRowsWithColumnsTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- setFieldValue(Hbase.getRowTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setFieldValue(Hbase.getRowTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- setFieldValue(Hbase.getRowWithColumns_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setFieldValue(Hbase.getRowWithColumns_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- setFieldValue(Hbase.getRowWithColumnsTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setFieldValue(Hbase.getRowWithColumnsTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- setFieldValue(Hbase.getTableNames_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- setFieldValue(Hbase.getTableNames_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- setFieldValue(Hbase.getTableRegions_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- setFieldValue(Hbase.getTableRegions_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- setFieldValue(Hbase.getVer_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setFieldValue(Hbase.getVer_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- setFieldValue(Hbase.getVerTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setFieldValue(Hbase.getVerTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- setFieldValue(Hbase.increment_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- setFieldValue(Hbase.increment_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- setFieldValue(Hbase.incrementRows_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- setFieldValue(Hbase.incrementRows_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- setFieldValue(Hbase.isTableEnabled_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- setFieldValue(Hbase.isTableEnabled_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- setFieldValue(Hbase.majorCompact_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- setFieldValue(Hbase.majorCompact_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- setFieldValue(Hbase.mutateRow_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setFieldValue(Hbase.mutateRow_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- setFieldValue(Hbase.mutateRows_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- setFieldValue(Hbase.mutateRows_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- setFieldValue(Hbase.mutateRowsTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- setFieldValue(Hbase.mutateRowsTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- setFieldValue(Hbase.mutateRowTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setFieldValue(Hbase.mutateRowTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- setFieldValue(Hbase.scannerClose_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- setFieldValue(Hbase.scannerClose_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- setFieldValue(Hbase.scannerGet_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- setFieldValue(Hbase.scannerGet_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setFieldValue(Hbase.scannerGetList_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- setFieldValue(Hbase.scannerGetList_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setFieldValue(Hbase.scannerOpen_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setFieldValue(Hbase.scannerOpen_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- setFieldValue(Hbase.scannerOpenTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setFieldValue(Hbase.scannerOpenTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- setFieldValue(Hbase.scannerOpenWithPrefix_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setFieldValue(Hbase.scannerOpenWithPrefix_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- setFieldValue(Hbase.scannerOpenWithScan_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- setFieldValue(Hbase.scannerOpenWithScan_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- setFieldValue(Hbase.scannerOpenWithStop_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setFieldValue(Hbase.scannerOpenWithStop_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- setFieldValue(Hbase.scannerOpenWithStopTs_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setFieldValue(Hbase.scannerOpenWithStopTs_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- setFieldValue(IllegalArgument._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- setFieldValue(IOError._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- setFieldValue(Mutation._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setFieldValue(TAppend._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- setFieldValue(TCell._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- setFieldValue(TColumn._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- setFieldValue(TIncrement._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setFieldValue(TRegionInfo._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setFieldValue(TRowResult._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setFieldValue(TScan._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setFieldValue(TAppend._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- setFieldValue(TAuthorization._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- setFieldValue(TCellVisibility._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
-
- setFieldValue(TColumn._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setFieldValue(TColumnIncrement._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setFieldValue(TColumnValue._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setFieldValue(TDelete._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setFieldValue(TGet._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setFieldValue(THBaseService.append_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
- setFieldValue(THBaseService.append_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- setFieldValue(THBaseService.checkAndDelete_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setFieldValue(THBaseService.checkAndDelete_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- setFieldValue(THBaseService.checkAndPut_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setFieldValue(THBaseService.checkAndPut_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- setFieldValue(THBaseService.closeScanner_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- setFieldValue(THBaseService.closeScanner_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- setFieldValue(THBaseService.deleteMultiple_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- setFieldValue(THBaseService.deleteMultiple_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- setFieldValue(THBaseService.deleteSingle_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- setFieldValue(THBaseService.deleteSingle_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- setFieldValue(THBaseService.exists_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- setFieldValue(THBaseService.exists_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- setFieldValue(THBaseService.get_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- setFieldValue(THBaseService.get_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- setFieldValue(THBaseService.getMultiple_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- setFieldValue(THBaseService.getMultiple_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- setFieldValue(THBaseService.getScannerResults_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- setFieldValue(THBaseService.getScannerResults_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- setFieldValue(THBaseService.getScannerRows_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- setFieldValue(THBaseService.getScannerRows_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- setFieldValue(THBaseService.increment_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- setFieldValue(THBaseService.increment_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- setFieldValue(THBaseService.mutateRow_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- setFieldValue(THBaseService.mutateRow_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- setFieldValue(THBaseService.openScanner_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- setFieldValue(THBaseService.openScanner_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- setFieldValue(THBaseService.put_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- setFieldValue(THBaseService.put_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- setFieldValue(THBaseService.putMultiple_args._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- setFieldValue(THBaseService.putMultiple_result._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- setFieldValue(TIllegalArgument._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- setFieldValue(TIncrement._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setFieldValue(TIOError._Fields, Object) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- setFieldValue(TPut._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setFieldValue(TResult._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- setFieldValue(TRowMutations._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- setFieldValue(TScan._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setFieldValue(TTimeRange._Fields, Object) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- setFileCreateTime(long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- setFileInfoOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setFileInfoOffset(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 file_info_offset = 1;
- setFilename(String) - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- setFileName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string file_name = 3;
- setFileNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string file_name = 3;
- setFileSize(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
optional uint64 file_size = 3;
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Get
-
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Query
-
Apply the specified server-side filter when performing the Query.
- setFilter(Filter) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setFilter(FilterProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .Filter filter = 4;
- setFilter(FilterProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .Filter filter = 4;
- setFilter(FilterProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .Filter filter = 5;
- setFilter(FilterProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .Filter filter = 5;
- setFilter(FilterProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
required .Filter filter = 1;
- setFilter(FilterProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterWrapper.Builder
-
required .Filter filter = 1;
- setFilter(FilterProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
required .Filter filter = 1;
- setFilter(FilterProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SkipFilter.Builder
-
required .Filter filter = 1;
- setFilter(FilterProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
required .Filter filter = 1;
- setFilter(FilterProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.WhileMatchFilter.Builder
-
required .Filter filter = 1;
- setFilter(String) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional string filter = 8;
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setFilter(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- setFilterBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional string filter = 8;
- setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Set whether entire row should be filtered if column is not found.
- setFilterIfMissing(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bool filter_if_missing = 5;
- setFilters(int, FilterProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- setFilters(int, FilterProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- setFilterString(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setFilterString(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setFilterString(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setFilterString(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setFilterString(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setFilterString(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setFilterStringIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setFilterStringIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setFilterStringIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setFindPort(boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setFirst(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
required bytes first = 1;
- setFirst(T1) - Method in class org.apache.hadoop.hbase.util.Pair
-
Replace the first element of the pair.
- setFirst(A) - Method in class org.apache.hadoop.hbase.util.Triple
-
- setFirstDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setFirstDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 first_data_block_offset = 9;
- setFirstInsertionIndex(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- setFirstPart(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
repeated bytes first_part = 1;
- setFirstRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- setFirstRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- setFirstRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
In HBase, the last row is represented by an empty byte array.
- setFirstRow(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Set the first row
- setFirstRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- setFirstRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- setFixAssignments(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Fix inconsistencies found by fsck.
- setFixEmptyMetaCells(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixHdfsHoles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixHdfsOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixHdfsOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixMeta(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixReferenceFiles(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixSplitParents(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixTableLocks(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Set table locks fix mode.
- setFixTableOrphans(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFixTableZNodes(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
Set orphaned table ZNodes fix mode.
- setFixVersionFile(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setFlushed(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
optional bool flushed = 2;
- setFlushOutput(int, String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
repeated string flush_output = 3;
- setFlushPolicyClassName(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
This sets the class associated with the flush policy which determines determines the stores
need to be flushed when flushing a region.
- setFlushSequenceNumber(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
optional uint64 flush_sequence_number = 4;
- setFollowingKvCount(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint32 following_kv_count = 7;
- setForce(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
optional bool force = 2 [default = false];
- setForcible(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
optional bool forcible = 3 [default = false];
- setForcible(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
optional bool forcible = 3 [default = false];
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setFormat(String) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl
-
- setFoundKV(boolean) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
-
- setFrags(Map<String, Integer>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setFrags(Map<String, Integer>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setFrom(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
optional uint64 from = 1;
- setFsDefault(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- setFsToken(SecureBulkLoadProtos.DelegationToken) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required .DelegationToken fs_token = 3;
- setFsToken(SecureBulkLoadProtos.DelegationToken.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
required .DelegationToken fs_token = 3;
- setFuzzyKeysData(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- setFuzzyKeysData(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- setGauge(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Set a gauge to a specific value.
- setGauge(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Set a single gauge to a value.
- setGeneralBloomFilterFaulty() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- setGenericException(ErrorHandlingProtos.GenericExceptionMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional .GenericExceptionMessage generic_exception = 2;
- setGenericException(ErrorHandlingProtos.GenericExceptionMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional .GenericExceptionMessage generic_exception = 2;
- setGet(ClientProtos.Get) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .Get get = 3;
- setGet(ClientProtos.Get.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .Get get = 3;
- setGet(ClientProtos.Get) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .Get get = 2;
- setGet(ClientProtos.Get.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .Get get = 2;
- setGet(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
the TGet to check for
- setGet(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
the TGet to fetch
- setGetIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- setGetIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- setGets(List<TGet>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
a list of TGets to fetch, the Result list
will have the Results at corresponding positions
or null if there was an error
- setGetsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- setGlobalMemstoreLimit(long) - Method in interface org.apache.hadoop.hbase.regionserver.FlushRequester
-
Sets the global memstore limit to a new size.
- setGlobalPermission(AccessControlProtos.GlobalPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .GlobalPermission global_permission = 2;
- setGlobalPermission(AccessControlProtos.GlobalPermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .GlobalPermission global_permission = 2;
- setHasCompression(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional bool has_compression = 1;
- setHash(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
optional bytes hash = 5;
- setHasMoreResultsContext(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- setHasTagCompression(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional bool has_tag_compression = 3;
- setHbaseVersion(FSProtos.HBaseVersionFileContent) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .HBaseVersionFileContent hbase_version = 1;
- setHbaseVersion(FSProtos.HBaseVersionFileContent.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .HBaseVersionFileContent hbase_version = 1;
- setHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- setHeaders(Header[]) - Method in class org.apache.hadoop.hbase.rest.client.Response
-
- setHeapOccupancy(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
optional int32 heapOccupancy = 2 [default = 0];
- setHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int32 heapSizeMB = 4;
- setHeartbeatMessage(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- setHeartbeatMessage(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool heartbeat_message = 9;
- setHfile(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string hfile = 3;
- setHfileBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string hfile = 3;
- setHFileCorruptionChecker(HFileCorruptionChecker) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setHostName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
required string host_name = 1;
- setHostname(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string hostname = 3;
- setHostNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
required string host_name = 1;
- setHostnameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string hostname = 3;
- setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setHTable(HTable) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Deprecated.
Use setTable() instead.
- setHTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Sets the HBase table.
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setIa(IllegalArgument) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setIa(TIllegalArgument) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
if the scannerId is invalid
- setIa(TIllegalArgument) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
if the scannerId is invalid
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- setIaIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.Append
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.Get
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.OperationWithAttributes
-
This method allows you to set an identifier on an operation.
- setId(String) - Method in class org.apache.hadoop.hbase.client.Put
-
- setId(String) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setId(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- setId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
required int32 id = 1;
- setId(long) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setId(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional int64 id = 4;
- setId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
id of a scanner returned by scannerOpen
- setId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
id of a scanner returned by scannerOpen
- setId(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
id of a scanner returned by scannerOpen
- setId(long) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setIdentifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
optional bytes identifier = 1;
- setIdentifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional bytes identifier = 1;
- setIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- setIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- setIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- setIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setIfOlderThanTs(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
optional uint64 if_older_than_ts = 2;
- setIgnoreDeleteForTesting(boolean) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
Temporary function that is used by unit tests only
- setIgnorePreCheckPermission(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setIncludesMvcc(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- setIncludesMvccVersion(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setIncludesMvccVersion(boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setIncludesTags(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- setIncludeSysTables(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional bool include_sys_tables = 3 [default = false];
- setIncludeSysTables(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional bool include_sys_tables = 2 [default = false];
- setIncrement(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
The single increment to apply
- setIncrement(TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
the TIncrement to increment
- setIncrementIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- setIncrementIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- setIncrements(List<TIncrement>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
The list of increments
- setIncrementsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- setIndex(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional uint32 index = 1;
- setIndex(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional uint32 index = 1;
- setInfoFamilyCachingForMeta(HTableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Enable in memory caching for hbase:meta
- setInfoPort(int) - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- setInfoPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionServerInfo.Builder
-
optional int32 infoPort = 1;
- setInfoPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
optional uint32 info_port = 3;
- setInfoServerPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint32 info_server_port = 9;
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional bool inMemory = 4;
- setInMemory(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setInMemoryIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setInput(JobConf, String, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableSnapshotInputFormat
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(Job, String, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormat
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInput(Configuration, String, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl
-
Configures the job to use TableSnapshotInputFormat to read from a snapshot.
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setInputColumns(byte[][]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setInsertionIndexes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- setInstance(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
optional string instance = 2;
- setInstanceBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
optional string instance = 2;
- setInterpreterClassName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required string interpreter_class_name = 1;
- setInterpreterClassNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required string interpreter_class_name = 1;
- setInterpreterSpecificBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
optional bytes interpreter_specific_bytes = 3;
- setIntHeader(String, int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- setIo(IOError) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- setIo(TIOError) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- setIoIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- setIsDelete(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setIsDeleteIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setIsMajor(boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Specify if this compaction should be a major compaction based on the state of the store
- setIsMasterRunning(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsMasterRunningResponse.Builder
-
required bool is_master_running = 1;
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Get
-
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Query
-
Set the isolation level for this query.
- setIsolationLevel(IsolationLevel) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setIsProcedureAborted(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureResponse.Builder
-
required bool is_procedure_aborted = 1;
- setIsRecovering(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
optional bool isRecovering = 3;
- setIsShared(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional bool is_shared = 4;
- setIssueDate(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
optional int64 issue_date = 4;
- setIv(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- setIv(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- setIv(byte[]) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Set the initialization vector
- setIv(byte[]) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Set the initialization vector
- setIv(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
optional bytes iv = 4;
- setJerseyVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setJerseyVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string jerseyVersion = 5;
- setJerseyVersionBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string jerseyVersion = 5;
- setJVMVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setJvmVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string jvmVersion = 2;
- setJvmVersionBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string jvmVersion = 2;
- setKeepDeletedCells(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setKeepDeletedCells(KeepDeletedCells) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setKeepDeletes(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- setKeepProgress(boolean) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
-
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.Context
-
- setKey(Key) - Method in interface org.apache.hadoop.hbase.io.crypto.Decryptor
-
Set the secret key
- setKey(Key) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
-
- setKey(byte[]) - Method in class org.apache.hadoop.hbase.io.crypto.Encryption.Context
-
- setKey(Key) - Method in interface org.apache.hadoop.hbase.io.crypto.Encryptor
-
Set the secret key
- setKey(byte[], int, int) - Method in class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
-
A setter that helps to avoid object creation every time and whenever
there is a need to create new KeyOnlyKeyValue.
- setKey(WALProtos.WALKey) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
required .WALKey key = 1;
- setKey(WALProtos.WALKey.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
required .WALKey key = 1;
- setKey(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey.Builder
-
required bytes key = 3;
- setKey(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
- setKey(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
required bytes key = 1;
- setKeyId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
required int32 key_id = 3;
- setKeytabConfKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setKeyType(CellProtos.CellType) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional .CellType key_type = 5;
- setKeyValueBytes(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
repeated bytes key_value_bytes = 2;
- setKind(AuthenticationProtos.TokenIdentifier.Kind) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
required .TokenIdentifier.Kind kind = 1;
- setKind(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional string kind = 3;
- setKindBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional string kind = 3;
- setLabel(int, String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
repeated string label = 1;
- setLabel(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
repeated bytes label = 1;
- setLabel(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
required bytes label = 1;
- setLabels(int, String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated string labels = 10;
- setLabels(List<String>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- setLabelsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- setLastAppliedOpAge(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- setLastAppliedOpAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
-
- setLastContact(long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- setLastDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setLastDataBlockOffset(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 last_data_block_offset = 10;
- setLastFlushedSequenceId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
required uint64 last_flushed_sequence_id = 1;
- setLastFlushedSequenceId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
required uint64 last_flushed_sequence_id = 1;
- setLastFlushTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
required uint64 last_flush_time = 1;
- setLastMajorCompactionTs(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 last_major_compaction_ts = 17 [default = 0];
- setLastQuery(long) - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
- setLastRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- setLastRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- setLastRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
In HBase, the last row is represented by an empty byte array.
- setLastRow(byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Set the last row
- setLastRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- setLastRow(byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- setLastShippedAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- setLastShippedAge(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- setLastShippedAge(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- setLastUpdate(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional uint64 last_update = 3;
- setLastUpdate(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required uint64 last_update = 8;
- setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Set whether only the latest version of the column value should be compared.
- setLatestVersionOnly(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueFilter.Builder
-
optional bool latest_version_only = 6;
- setLeastSigBits(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
required uint64 least_sig_bits = 1;
- setLenAsVal(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.KeyOnlyFilter.Builder
-
required bool len_as_val = 1;
- setLength(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey.Builder
-
required uint32 length = 2;
- setLength(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.CellBlockMeta.Builder
-
optional uint32 length = 1;
- setLength(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- setLength(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
Update the length of this range.
- setLength(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Update the length of this range.
- setLength(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- setLength(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Update the length of this range.
- setLimit(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnCountGetFilter.Builder
-
required int32 limit = 1;
- setLimit(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
required int32 limit = 1;
- setLimit(int) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl.ImplData
-
- setLimit(int) - Method in class org.apache.hadoop.hbase.tmpl.master.AssignmentManagerStatusTmpl
-
- setLimit(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- setLimit(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Limits the byte range upto a specified value.
- setLimit(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- setLineNumber(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional int32 line_number = 4;
- setListener(EventHandler.EventHandlerListener) - Method in class org.apache.hadoop.hbase.executor.EventHandler
-
- setLiveNodes(List<StorageClusterStatusModel.Node>) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- setLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- setLiveServers(int, ClusterStatusProtos.LiveServerInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- setLiveServers(int, ClusterStatusProtos.LiveServerInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- setLoad(ClusterStatusProtos.ServerLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
optional .ServerLoad load = 2;
- setLoad(ClusterStatusProtos.ServerLoad.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
optional .ServerLoad load = 2;
- setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the value indicating whether loading CFs on demand should be allowed (cluster
default is false).
- setLoadColumnFamiliesOnDemand(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool load_column_families_on_demand = 13;
- setLoaded(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileResponse.Builder
-
required bool loaded = 1;
- setLoaded(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesResponse.Builder
-
required bool loaded = 1;
- setLoadOnOpenDataOffset(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 load_on_open_data_offset = 2;
- setLoadOnOpenOffset(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setLoadStats(ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .RegionLoadStats loadStats = 5;
- setLoadStats(ClientProtos.RegionLoadStats.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .RegionLoadStats loadStats = 5;
- setLocation(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- setLocation(String) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setLocation(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional string location = 5;
- setLocationBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional string location = 5;
- setLocations(Path, Path...) - Method in class org.apache.hadoop.hbase.io.FileLink
-
NOTE: This method must be used only in the constructor!
It creates a List with the specified locations for the link.
- setLocations(int, String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
repeated string locations = 2;
- setLockOwner(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
required string lock_owner = 1;
- setLockOwner(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .ServerName lock_owner = 2;
- setLockOwner(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .ServerName lock_owner = 2;
- setLockOwnerBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationLock.Builder
-
required string lock_owner = 1;
- setLogDir(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setLoggingUncaughtExceptionHandler(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Sets an UncaughtExceptionHandler for the thread which logs the
Exception stack if the thread dies.
- setLogId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint64 log_id = 3;
- setLogPosition(String, String, long) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Set the current position for a specific WAL in a given queue.
- setLogPosition(String, String, long) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- setLogRecoveryMode() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
The function is used in SSH to set recovery mode based on configuration after all outstanding
log split tasks drained.
- setLogSeqNum(long) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
Allow that the log sequence id to be set post-construction and release all waiters on assigned
sequence number.
- setLogSequenceNumber(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional uint64 log_sequence_number = 4;
- setLogSequenceNumber(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required uint64 log_sequence_number = 3;
- setLongMsg(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.LongMsg.Builder
-
required int64 long_msg = 1;
- setMajor(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
optional bool major = 2;
- setMajorRange(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
Sets compaction "major range".
- setMapEntries(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- setMapEntries(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- setMapEntry(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- setMapEntry(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- setMapperClass(Job, Class<? extends Mapper<ImmutableBytesWritable, Result, K2, V2>>) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Set the application's mapper class.
- setMaster(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ServerName master = 7;
- setMaster(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
optional .ServerName master = 7;
- setMaster(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
required .ServerName master = 1;
- setMaster(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
required .ServerName master = 1;
- setMaster(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.BackupMasterStatusTmpl.ImplData
-
- setMaster(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setMaster(HMaster) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
-
- setMasterAddress(ZooKeeperWatcher, String, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
Set master address into the master
znode or into the backup
subdirectory of backup masters; switch off the passed in znode
path.
- setMasterCoprocessors(int, HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- setMasterCoprocessors(int, HBaseProtos.Coprocessor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- setMasterServices(MasterServices) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- setMasterServices(MasterServices) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
-
Set the master service.
- setMasterSystemTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
optional uint64 master_system_time = 4;
- setMasterSystemTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
optional uint64 master_system_time = 5;
- setMaxAttempts(int) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- setMaxChunkSize(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- setMaxColumn(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bytes max_column = 3;
- setMaxColumnInclusive(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bool max_column_inclusive = 4;
- setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setMaxFileSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Sets the maximum size upto which a region can grow to after which a region
split is triggered.
- setMaxHeapMB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint32 max_heap_MB = 4;
- setMaxHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setMaxHeapSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int32 maxHeapSizeMB = 5;
- setMaxMemstoreTS(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
- setMaxMerge(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setMaxOverlapsToSideline(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setMaxPoolSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- setMaxPoolSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- setMaxQualifierLength(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setMaxQueueSize(int) - Method in class org.apache.hadoop.hbase.thrift.IncrementCoalescer
-
- setMaxQueueSize(int) - Method in interface org.apache.hadoop.hbase.thrift.IncrementCoalescerMBean
-
- setMaxResultSize(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum result size.
- setMaxResultSize(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint64 max_result_size = 10;
- setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Set the maximum number of values to return per row per Column Family
- setMaxResultsPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the maximum number of values to return per row per Column Family
- setMaxRowLength(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- setMaxSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- setMaxSize(long) - Method in interface org.apache.hadoop.hbase.io.hfile.ResizableBlockCache
-
Sets the max heap size that can be used by the BlockCache.
- setMaxSleepTime(long) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- setMaxStamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- setMaxStampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- setMaxTagsLength(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setMaxValues(int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Get
-
Get all available versions.
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Get up to the specified number of versions of each column.
- setMaxVersions() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get all available versions.
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get up to the specified number of versions of each column.
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional uint32 max_versions = 6 [default = 1];
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 max_versions = 7 [default = 1];
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional int32 maxVersions = 4;
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int32 maxVersions = 7;
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setMaxVersions(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setMaxVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setMaxVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setMaxVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setMayInterruptIfRunning(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
optional bool mayInterruptIfRunning = 2 [default = true];
- setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setMemStoreFlushSize(long) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Represents the maximum size of the memstore after which the contents of the
memstore are flushed to the filesystem.
- setMemstoreLoad(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionLoadStats.Builder
-
optional int32 memstoreLoad = 1 [default = 0];
- setMemstoreSize(float) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerResult
-
- setMemstoreSizeMB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 memstore_size_MB = 6;
- setMemstoreSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setMemstoreSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 memstoreSizeMB = 5;
- setMerged(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- setMessage(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional string message = 2;
- setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- setMessage(String) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- setMessageBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
optional string message = 2;
- setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift.generated.IOError
-
- setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- setMessageIsSet(boolean) - Method in exception org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- setMetaIndexCount(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setMetaIndexCount(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 meta_index_count = 6;
- setMetaLocation(ServerName) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setMetaLocation(ServerName) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setMetaLocation(ZooKeeperWatcher, ServerName, RegionState.State) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Sets the location of hbase:meta
in ZooKeeper to the
specified server address.
- setMetaLocation(ZooKeeperWatcher, ServerName, int, RegionState.State) - Static method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Sets the location of hbase:meta
in ZooKeeper to the
specified server address.
- setMetaRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used to denote if the current table represents
-ROOT-
or hbase:meta
region.
- setMethodName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required string method_name = 3;
- setMethodName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string method_name = 2;
- setMethodName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional string method_name = 3;
- setMethodNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required string method_name = 3;
- setMethodNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage.Builder
-
optional string method_name = 2;
- setMethodNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional string method_name = 3;
- setMetrics(int, HBaseProtos.NameInt64Pair) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- setMetrics(int, HBaseProtos.NameInt64Pair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- setMinColumn(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bytes min_column = 1;
- setMinColumnInclusive(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnRangeFilter.Builder
-
optional bool min_column_inclusive = 2;
- setMinIndexNumEntries(int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
- setMinMvccVersion(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setMinProcId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint64 min_proc_id = 4;
- setMinStamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- setMinStampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- setMinTimestamp(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setMinVersions(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setMode(ZooKeeperProtos.SplitLogTask.RecoveryMode) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
optional .SplitLogTask.RecoveryMode mode = 3 [default = UNKNOWN];
- setModifiedTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .TableSchema modified_table_schema = 3;
- setModifiedTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .TableSchema modified_table_schema = 3;
- setMoreResults(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool more_results = 3;
- setMoreResultsInRegion(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool more_results_in_region = 8;
- setMostSigBits(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.UUID.Builder
-
required uint64 most_sig_bits = 2;
- setMput(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
mutation for the put
- setMputIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- setMutateType(ClientProtos.MutationProto.MutationType) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .MutationProto.MutationType mutate_type = 2;
- setMutation(ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .MutationProto mutation = 2;
- setMutation(ClientProtos.MutationProto.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .MutationProto mutation = 2;
- setMutation(ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .MutationProto mutation = 2;
- setMutation(ClientProtos.MutationProto.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .MutationProto mutation = 2;
- setMutationRequest(int, ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- setMutationRequest(int, ClientProtos.MutationProto.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- setMutations(List<Mutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- setMutations(List<Mutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
list of mutation commands
- setMutations(List<Mutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
list of mutation commands
- setMutations(List<TMutation>) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- setMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- setMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- setMvccVersionDeltaWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setMvccVersionFields(LongEncoder) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setMvccVersionIndexWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setMWrap(MetricsRegionServerWrapper) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.ServerMetricsTmpl.ImplData
-
- setName(byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setName(TableName) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setName(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Deprecated.
- setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
required string name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
required string name = 1;
- setName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
required bytes name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
required string name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
required string name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
optional string name = 1;
- setName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
required bytes name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
required string name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
required string name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
required string name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
- setName(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableModel
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
required string name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional string name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
required string name = 1;
- setName(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
required bytes name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
required string name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
required string name = 1;
- setName(int, String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
repeated string name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
required string name = 1;
- setName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional string name = 1;
- setName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setName(String) - Method in class org.apache.hadoop.hbase.util.HasThread
-
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.Coprocessor.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
optional string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
required string name = 1;
- setNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional string name = 1;
- setNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setNamespace(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
required bytes namespace = 1;
- setNamespace(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional string namespace = 4;
- setNamespace(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional string namespace = 3;
- setNamespace(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string namespace = 3;
- setNamespace(String) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setNamespaceBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional string namespace = 4;
- setNamespaceBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional string namespace = 3;
- setNamespaceBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string namespace = 3;
- setNamespaceDescriptor(HBaseProtos.NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- setNamespaceDescriptor(HBaseProtos.NamespaceDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- setNamespaceDescriptor(HBaseProtos.NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- setNamespaceDescriptor(HBaseProtos.NamespaceDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorResponse.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- setNamespaceDescriptor(int, HBaseProtos.NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- setNamespaceDescriptor(int, HBaseProtos.NamespaceDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- setNamespaceDescriptor(HBaseProtos.NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- setNamespaceDescriptor(HBaseProtos.NamespaceDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyNamespaceRequest.Builder
-
required .NamespaceDescriptor namespaceDescriptor = 1;
- setNamespaceFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the namespace filter regex
- setNamespaceGroupPermissions(String, String, List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Overwrites the existing permission set for a group and triggers an update
for zookeeper synchronization.
- setNamespaceName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional bytes namespace_name = 3;
- setNamespaceName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
optional bytes namespace_name = 1;
- setNamespaceName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
required string namespaceName = 1;
- setNamespaceName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
required string namespaceName = 1;
- setNamespaceName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
required string namespaceName = 1;
- setNamespaceName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
required string namespaceName = 1;
- setNamespaceNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteNamespaceRequest.Builder
-
required string namespaceName = 1;
- setNamespaceNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetNamespaceDescriptorRequest.Builder
-
required string namespaceName = 1;
- setNamespaceNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceRequest.Builder
-
required string namespaceName = 1;
- setNamespaceNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceRequest.Builder
-
required string namespaceName = 1;
- setNamespacePermission(AccessControlProtos.NamespacePermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .NamespacePermission namespace_permission = 3;
- setNamespacePermission(AccessControlProtos.NamespacePermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .NamespacePermission namespace_permission = 3;
- setNamespaceQuota(String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setNamespaceQuota(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setNamespaceUserPermissions(String, String, List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Overwrites the existing permission set for a given user for a table, and
triggers an update for zookeeper synchronization.
- setNbRows(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
number of results to return
- setNbRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- setNegativeIndex(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- setNextCallSeq(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional uint64 next_call_seq = 6;
- setNextNodeOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNextPtr(LruHashMap.Entry<K, V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Sets the next pointer for the entry in the LRU.
- setNextRefillTime(long) - Method in class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
-
- setNextRefillTime(long) - Method in class org.apache.hadoop.hbase.quotas.FixedIntervalRateLimiter
-
- setNextRefillTime(long) - Method in class org.apache.hadoop.hbase.quotas.RateLimiter
-
- setNextState(MasterProcedureProtos.AddColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- setNextState(MasterProcedureProtos.CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- setNextState(MasterProcedureProtos.DeleteColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- setNextState(MasterProcedureProtos.DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- setNextState(MasterProcedureProtos.EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- setNextState(MasterProcedureProtos.ModifyColumnFamilyState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- setNextState(MasterProcedureProtos.ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- setNextState(TState) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
Set the next state for the procedure.
- setNode(int, ProcedureProtos.ProcedureStoreTracker.TrackerNode) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- setNode(int, ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- setNodeFirstInsertionIndexes() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
write
- setNonce(long) - Method in class org.apache.hadoop.hbase.client.Action
-
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional uint64 nonce = 9;
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
optional uint64 nonce = 3 [default = 0];
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
optional uint64 nonce = 3 [default = 0];
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
optional uint64 nonce = 3 [default = 0];
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
optional uint64 nonce = 4 [default = 0];
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
optional uint64 nonce = 3;
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint64 nonce = 14 [default = 0];
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional uint64 nonce = 5;
- setNonce(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint64 nonce = 10;
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.client.MultiAction
-
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
optional uint64 nonceGroup = 2;
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
optional uint64 nonce_group = 4;
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
optional uint64 nonce_group = 2 [default = 0];
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
optional uint64 nonce_group = 2 [default = 0];
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
optional uint64 nonce_group = 2 [default = 0];
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
optional uint64 nonce_group = 3 [default = 0];
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
optional uint64 nonce_group = 2;
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint64 nonce_group = 13 [default = 0];
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional uint64 nonce_group = 4;
- setNonceGroup(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint64 nonceGroup = 9;
- setNonceKey(NonceKey) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor to set the value to the newly created procedure.
- setNonSeekedState() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.ScannerV2
-
- setNonSeekedState() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV3.ScannerV3
-
- setNoStripeMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- setNumberOfRequests(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 number_of_requests = 1;
- setNumberOfRowPrefixes(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setNumberOfRows(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional uint32 number_of_rows = 4;
- setNumberOfRows(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setNumberOfThreads(Job, int) - Static method in class org.apache.hadoop.hbase.mapreduce.MultithreadedTableMapper
-
Set the number of threads in the pool for running maps.
- setNumDataIndexLevels(int) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setNumDataIndexLevels(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint32 num_data_index_levels = 8;
- setNumFamilyBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumKeyValueBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumMapTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets the number of map tasks for the given job configuration to the
number of regions the given table has.
- setNumMetaBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumMvccVersionBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumOccurrences(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- setNumQualifierBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumReduceTasks(String, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets the number of reduce tasks for the given job configuration to the
number of regions the given table has.
- setNumReduceTasks(String, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets the number of reduce tasks for the given job configuration to the
number of regions the given table has.
- setNumRowBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumRows(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
number of rows to return
- setNumRows(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
number of rows to return
- setNumRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- setNumRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- setNumTagsBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumTimestampBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumUniqueFamilies(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumUniqueQualifiers(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumUniqueRows(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumUniqueTags(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumValueBytes(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setNumVersions(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
number of versions to retrieve
- setNumVersions(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
number of versions to retrieve
- setNumVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setNumVersionsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setOffline(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
The parent of a region split is offline while split daughters hold
references to the parent.
- setOffline(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bool offline = 5;
- setOffPeak(boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
- setOffset(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPaginationFilter.Builder
-
optional int32 offset = 2;
- setOffset(int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- setOffset(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
Update the beginning of this range.
- setOffset(int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Update the beginning of this range.
- setOffset(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- setOffset(int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Update the beginning of this range.
- setOn(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
required bool on = 1;
- setOnlineRegions(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
-
- setOpenForDistributedLogReplay(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
optional bool openForDistributedLogReplay = 4;
- setOpenInfo(int, AdminProtos.OpenRegionRequest.RegionOpenInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- setOpenInfo(int, AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- setOpeningState(int, AdminProtos.OpenRegionResponse.RegionOpeningState) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- setOpenSeqNum(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
optional uint64 open_seq_num = 3;
- setOperationStatus(int, OperationStatus) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Sets the status code for the operation(Mutation) at the specified position.
- setOperationTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
-
- setOperator(FilterProtos.FilterList.Operator) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
required .FilterList.Operator operator = 1;
- setOrdinal(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel.Builder
-
optional uint32 ordinal = 2;
- setOrigLogSeqNum(long) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
Used to set original seq Id for WALKey during wal replay
- setOrigSequenceNumber(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
optional uint64 orig_sequence_number = 11;
- setOSVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setOsVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string osVersion = 3;
- setOsVersionBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string osVersion = 3;
- setOutputArrayOffset(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- setOwner(User) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setOwner(String) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setOwner(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional string owner = 6;
- setOwner(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional string owner = 5;
- setOwnerBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional string owner = 6;
- setOwnerBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional string owner = 5;
- setOwnerString(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Deprecated.
- setPageSize(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PageFilter.Builder
-
required int64 page_size = 1;
- setParent(TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- setParentId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint64 parent_id = 2;
- setParentId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
optional int64 parent_id = 2;
- setParentProcId(long) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor to assign the parent to the newly created procedure.
- setParentStartPosition(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
-
get/set
- setPartial(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional bool partial = 5 [default = false];
- setPartialFlag(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- setPartialFlagPerResult(int, boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated bool partial_flag_per_result = 7;
- setPassword(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
optional bytes password = 2;
- setPassword(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional bytes password = 2;
- setPath(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
required string path = 2;
- setPathBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder
-
required string path = 2;
- setPathSpec(String[]) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setPattern(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required string pattern = 1;
- setPatternBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required string pattern = 1;
- setPatternFlags(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator.Builder
-
required int32 pattern_flags = 2;
- setPayload(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
optional bytes payload = 5;
- setPeerID(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required string peerID = 1;
- setPeerIDBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required string peerID = 1;
- setPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- setPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Set the replicable table-cf config of the specified peer
- setPeerTableCFsConfig(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Set the table and column-family list string of the peer to ZK.
- setPeerTableCFsConfig(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- setPermission(int, AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- setPermission(int, AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- setPermission(AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
required .Permission permission = 3;
- setPermission(AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
required .Permission permission = 3;
- setPermissions(int, AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- setPermissions(int, AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- setPolicy(HttpConfig.Policy) - Method in class org.apache.hadoop.hbase.http.HttpConfig
-
- setPort(int) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Deprecated.
- setPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
optional uint32 port = 2;
- setPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
required uint32 port = 1;
- setPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional int32 port = 4;
- setPort(int) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setPortIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setPosition(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationHLogPosition.Builder
-
required int64 position = 1;
- setPosition(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationWALReaderManager
-
- setPosition(int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- setPosition(int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
Update the position
index.
- setPrefetchBlocksOnOpen(boolean) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setPrefix(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.ColumnPrefixFilter.Builder
-
required bytes prefix = 1;
- setPrefix(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.PrefixFilter.Builder
-
optional bytes prefix = 1;
- setPrefixLengthVariance(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setPreserveSplits(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
required bool preserve_splits = 2;
- setPreserveSplits(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
optional bool preserveSplits = 2 [default = false];
- setPrevBalanceValue(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningResponse.Builder
-
optional bool prev_balance_value = 1;
- setPrevPtr(LruHashMap.Entry<K, V>) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Sets the previous pointer for the entry in the LRU.
- setPrevValue(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableCatalogJanitorResponse.Builder
-
optional bool prev_value = 1;
- setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
-
- setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- setPriority(TableName) - Method in class org.apache.hadoop.hbase.ipc.PayloadCarryingRpcController
-
- setPriority(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional uint32 priority = 6;
- setPriority(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Sets the priority for the request
- setPriority(int) - Method in class org.apache.hadoop.hbase.util.HasThread
-
- setProcedure(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
required .ProcedureDescription procedure = 1;
- setProcedure(HBaseProtos.ProcedureDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureRequest.Builder
-
required .ProcedureDescription procedure = 1;
- setProcedure(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
optional .ProcedureDescription procedure = 1;
- setProcedure(HBaseProtos.ProcedureDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneRequest.Builder
-
optional .ProcedureDescription procedure = 1;
- setProcedure(int, ProcedureProtos.Procedure) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- setProcedure(int, ProcedureProtos.Procedure.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- setProcedure(int, ProcedureProtos.Procedure) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- setProcedure(int, ProcedureProtos.Procedure.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- setProcessed(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
optional bool processed = 2;
- setProcessed(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
optional bool processed = 2;
- setProcId(long) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the ProcedureExecutor to assign the ID to the newly created procedure.
- setProcId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AbortProcedureRequest.Builder
-
required uint64 proc_id = 1;
- setProcId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableResponse.Builder
-
optional uint64 proc_id = 1;
- setProcId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableResponse.Builder
-
optional uint64 proc_id = 1;
- setProcId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableResponse.Builder
-
optional uint64 proc_id = 1;
- setProcId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableResponse.Builder
-
optional uint64 proc_id = 1;
- setProcId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultRequest.Builder
-
required uint64 proc_id = 1;
- setProcId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required uint64 proc_id = 3;
- setProcId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
optional uint64 proc_id = 3;
- setProcIds(long, long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
-
- setPublishStatusInZk(boolean) - Method in class org.apache.hadoop.hbase.coordination.ZkCloseRegionCoordination.ZkCloseRegionDetails
-
- setPurpose(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional string purpose = 5;
- setPurposeBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional string purpose = 5;
- setPut(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
the TPut to put if the check succeeds
- setPut(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
the TPut to put
- setPut(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- setPutIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setPutIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- setPuts(List<TPut>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
a list of TPuts to commit
- setPutsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- setQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional bytes qualifier = 3;
- setQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes qualifier = 3;
- setQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
required bytes qualifier = 3;
- setQualifier(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
repeated bytes qualifier = 2;
- setQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required bytes qualifier = 3;
- setQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional bytes qualifier = 1;
- setQualifier(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableName.Builder
-
required bytes qualifier = 2;
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
column qualifier to check
- setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setQualifier(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
column qualifier to check
- setQualifier(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setQualifierIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setQualifierLengthVariance(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setQualifierOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setQualifiers(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
repeated bytes qualifiers = 1;
- setQualifierValue(int, ClientProtos.MutationProto.ColumnValue.QualifierValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- setQualifierValue(int, ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- setQuota(QuotaSettings) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Apply the new quota settings.
- setQuota(QuotaSettings) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Apply the new quota settings.
- setQuota(RpcController, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- setQuota(RpcController, MasterProtos.SetQuotaRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- setQuota(RpcController, MasterProtos.SetQuotaRequest, RpcCallback<MasterProtos.SetQuotaResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc SetQuota(.SetQuotaRequest) returns (.SetQuotaResponse);
- setQuota(RpcController, MasterProtos.SetQuotaRequest, RpcCallback<MasterProtos.SetQuotaResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc SetQuota(.SetQuotaRequest) returns (.SetQuotaResponse);
- setQuota(RpcController, MasterProtos.SetQuotaRequest, RpcCallback<MasterProtos.SetQuotaResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- setQuota(MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setQuotas(QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.QuotaState
-
Setup the global quota information.
- setQuotas(QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
- setQuotas(TableName, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Add the quota information of the specified table.
- setQuotas(String, QuotaProtos.Quotas) - Method in class org.apache.hadoop.hbase.quotas.UserQuotaState
-
Add the quota information of the specified namespace.
- setRackManager(RackManager) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- setRandomizer(Random) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setRange(FSProtos.Reference.Range) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
required .Reference.Range range = 2;
- setRaw(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Enable/disable "raw" mode for this scan.
- setReadNum(QuotaProtos.TimedQuota) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_num = 5;
- setReadNum(QuotaProtos.TimedQuota.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_num = 5;
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Setting the table as read only sets all the columns in the table as read
only.
- setReadOnly(boolean) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
optional bool readOnly = 5;
- setReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 read_requests_count = 8;
- setReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 readRequestsCount = 7;
- setReadsEnabled(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- setReadSize(QuotaProtos.TimedQuota) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_size = 6;
- setReadSize(QuotaProtos.TimedQuota.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota read_size = 6;
- setRealUser(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
optional string real_user = 2;
- setRealUserBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.UserInformation.Builder
-
optional string real_user = 2;
- setReason(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
required string reason = 1;
- setReason(String) - Method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- setReasonBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.StopServerRequest.Builder
-
required string reason = 1;
- setRecovering(boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Reset recovering state of current region
- setRecoveryMode(boolean) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
Change the recovery mode.
- setRecoveryMode(boolean) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
This function is to set recovery mode from outstanding split log tasks from before or current
configuration setting
- setRecoveryMode(boolean) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
This function is to set recovery mode from outstanding split log tasks from before or current
configuration setting
- setReference(FSProtos.Reference) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
optional .Reference reference = 2;
- setReference(FSProtos.Reference.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder
-
optional .Reference reference = 2;
- setRegex(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional string regex = 2;
- setRegex(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional string regex = 1;
- setRegex(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
optional string regex = 1;
- setRegexBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
optional string regex = 2;
- setRegexBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesRequest.Builder
-
optional string regex = 1;
- setRegexBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsRequest.Builder
-
optional string regex = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CompactRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
required .RegionInfo region = 1;
- setRegion(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
required .RegionInfo region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
required .RegionInfo region = 1;
- setRegion(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
required .RegionInfo region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .RegionInfo region = 4;
- setRegion(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .RegionInfo region = 4;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AssignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampForRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.OfflineRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegion(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.UnassignRegionRequest.Builder
-
required .RegionSpecifier region = 1;
- setRegionA(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- setRegionA(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- setRegionA(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- setRegionA(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_a = 1;
- setRegionAction(int, ClientProtos.RegionAction) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- setRegionAction(int, ClientProtos.RegionAction.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- setRegionActionResult(int, ClientProtos.RegionActionResult) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- setRegionActionResult(int, ClientProtos.RegionActionResult.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- setRegionB(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- setRegionB(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.MergeRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- setRegionB(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- setRegionB(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DispatchMergingRegionsRequest.Builder
-
required .RegionSpecifier region_b = 2;
- setRegionCachePrefetch(TableName, boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
does nothing since since 0.99
- setRegionCachePrefetch(byte[], boolean) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
Deprecated.
does nothing since 0.99
- setRegionCachePrefetch(byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
does nothing since 0.99
- setRegionCachePrefetch(TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
does nothing since 0.99
- setRegionCachePrefetch(Configuration, byte[], boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
does nothing since 0.99
- setRegionCachePrefetch(Configuration, TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.HTable
-
Deprecated.
does nothing since 0.99
- setRegionCoprocessorHost(RegionCoprocessorHost) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Sets the region coprocessor env.
- setRegionFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the region by which output will be filtered
- setRegionId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
required uint64 region_id = 1;
- setRegionInfo(int, HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- setRegionInfo(int, HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- setRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
required .RegionInfo region_info = 1;
- setRegionInfo(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetRegionInfoResponse.Builder
-
required .RegionInfo region_info = 1;
- setRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
required .RegionInfo regionInfo = 1;
- setRegionInfo(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WarmupRegionRequest.Builder
-
required .RegionInfo regionInfo = 1;
- setRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
required .RegionInfo region_info = 1;
- setRegionInfo(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
required .RegionInfo region_info = 1;
- setRegionInfo(int, HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- setRegionInfo(int, HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- setRegionInfo(int, HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- setRegionInfo(int, HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- setRegionInfo(int, HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- setRegionInfo(int, HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- setRegionInfo(int, HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- setRegionInfo(int, HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- setRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
required .RegionInfo region_info = 2;
- setRegionInfo(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
required .RegionInfo region_info = 2;
- setRegionLoads(int, ClusterStatusProtos.RegionLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- setRegionLoads(int, ClusterStatusProtos.RegionLoad.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- setRegionManifests(int, SnapshotProtos.SnapshotRegionManifest) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- setRegionManifests(int, SnapshotProtos.SnapshotRegionManifest.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- setRegionMemstoreReplication(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Enable or Disable the memstore replication from the primary region to the replicas.
- setRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdRequest.Builder
-
required bytes region_name = 1;
- setRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
optional bytes region_name = 7;
- setRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
optional bytes region_name = 6;
- setRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional bytes region_name = 7;
- setRegionName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required bytes region_name = 2;
- setRegionReplication(int) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Sets the number of replicas per region.
- setRegions(List<StorageClusterStatusModel.Node.Region>) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setRegions(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setRegions(List<TableRegionModel>) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
- setRegions(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
optional int32 regions = 3;
- setRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- setRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- setRegions(int, TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- setRegions(int, TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- setRegionServer(HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RegionListTmpl.ImplData
-
- setRegionServer(HRegionServer) - Method in class org.apache.hadoop.hbase.tmpl.regionserver.RSStatusTmpl.ImplData
-
- setRegionServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
Set the list of region servers for that peer
- setRegionsInTransition(int, ClusterStatusProtos.RegionInTransition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- setRegionsInTransition(int, ClusterStatusProtos.RegionInTransition.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- setRegionSpecifier(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
required .RegionSpecifier region_specifier = 1;
- setRegionSpecifier(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
required .RegionSpecifier region_specifier = 1;
- setRegionSplitPolicyClassName(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
This sets the class associated with the region split policy which
determines when a region split should occur.
- setRegionState(ClusterStatusProtos.RegionState) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionState region_state = 2;
- setRegionState(ClusterStatusProtos.RegionState.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionState region_state = 2;
- setRegionsToReopen(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Set the list of regions that will be reopened
because of an update in table schema
- setRegionToFlush(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
repeated bytes region_to_flush = 1;
- setRemoveAll(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional bool remove_all = 5;
- setRenew(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
Indicate whether we make a call only to renew the lease, but without affected the scanner in
any other way.
- setRenew(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional bool renew = 10 [default = false];
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Get
-
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Query
-
Specify region replica id where Query will fetch data from.
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setReplicaId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional int32 replica_id = 7 [default = 0];
- setReplicationEndpointImpl(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
optional string replicationEndpointImpl = 2;
- setReplicationEndpointImpl(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
-
Sets the ReplicationEndpoint plugin class for this peer.
- setReplicationEndpointImplBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
optional string replicationEndpointImpl = 2;
- setReplicationLag(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint64 replicationLag = 5;
- setReplLoadSink(ClusterStatusProtos.ReplicationLoadSink) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional .ReplicationLoadSink replLoadSink = 11;
- setReplLoadSink(ClusterStatusProtos.ReplicationLoadSink.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional .ReplicationLoadSink replLoadSink = 11;
- setReplLoadSource(int, ClusterStatusProtos.ReplicationLoadSource) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- setReplLoadSource(int, ClusterStatusProtos.ReplicationLoadSource.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- setReportEndTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 report_end_time = 8;
- setReportStartTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 report_start_time = 7;
- setReqNum(QuotaProtos.TimedQuota) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_num = 1;
- setReqNum(QuotaProtos.TimedQuota.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_num = 1;
- setReqSize(QuotaProtos.TimedQuota) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_size = 2;
- setReqSize(QuotaProtos.TimedQuota.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota req_size = 2;
- setRequest(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required bytes request = 4;
- setRequest(CompactionRequest) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- setRequestParam(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional bool request_param = 4;
- setRequests(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setRequests(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
- setRequests(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
optional int64 requests = 4;
- setRequests(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int64 requests = 3;
- setResponse(Message, CellScanner) - Method in class org.apache.hadoop.hbase.ipc.Call
-
Set the return value when there is no error.
- setResponse(Object, CellScanner, Throwable, String) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- setResponse(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesResponse.Builder
-
optional uint32 response = 1;
- setRESTVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setRestVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string restVersion = 1;
- setRestVersionBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string restVersion = 1;
- setResult(byte[]) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
The procedure may leave a "result" on completion.
- setResult(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
optional .Result result = 1;
- setResult(ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.GetResponse.Builder
-
optional .Result result = 1;
- setResult(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
optional .Result result = 1;
- setResult(ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutateResponse.Builder
-
optional .Result result = 1;
- setResult(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .Result result = 2;
- setResult(ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .Result result = 2;
- setResult(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional bytes result = 4;
- setResult(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional bytes result = 11;
- setResult(int, ClientProtos.RegionActionResult) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- setResult(int, ClientProtos.RegionActionResult.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- setResultOrException(int, ClientProtos.ResultOrException) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- setResultOrException(int, ClientProtos.ResultOrException.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- setResults(int, ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- setResults(int, ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- setRetainDays(int) - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- setRetCode(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setReturnData(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ExecProcedureResponse.Builder
-
optional bytes return_data = 2;
- setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Append
-
- setReturnResults(boolean) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether this scan is a reversed one
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.Filter
-
alter the reversed scan flag
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool reversed = 15 [default = false];
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setReversed(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setReversedIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setReversedIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setRevision(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string revision = 3;
- setRevisionBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string revision = 3;
- setRIT(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the number of regions in transition.
- setRIT(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setRITCountOverThreshold(int) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the count of the number of regions that have been in transition over the threshold time.
- setRITCountOverThreshold(int) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setRITOldestAge(long) - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
Set the oldest region in transition.
- setRITOldestAge(long) - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
-
- setRootDir(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
- setRootIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 root_index_size_KB = 12;
- setRootIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setRootIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 rootIndexSizeKB = 9;
- setRootRegion(boolean) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
INTERNAL Used to denote if the current table represents
-ROOT-
region.
- setRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes row = 1;
- setRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
required bytes row = 1;
- setRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Condition.Builder
-
required bytes row = 1;
- setRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required bytes row = 1;
- setRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
required bytes row = 1;
- setRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional bytes row = 1;
- setRow(byte[], int, short) - Method in class org.apache.hadoop.hbase.regionserver.ScanQueryMatcher
-
Set current row
- setRow(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional bytes row = 1;
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
row to increment
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Row to update
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
key of the row to be completely deleted.
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
key of the row to be completely deleted.
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Row to update
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
row key
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
row to check
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
row to check
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- setRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- setRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- setRowBatches(List<BatchMutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
list of row batches
- setRowBatches(List<BatchMutation>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
list of row batches
- setRowBatchesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- setRowBatchesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- setRowBatchSize(int) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required uint32 rowBatchSize = 4;
- setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
Allows subclasses to set the
Filter
to be used.
- setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setRowFilter(Filter) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setRowFilter(String) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the region by which output will be filtered
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- setRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- setRowMutations(TRowMutations) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
mutations to apply
- setRowMutationsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Get
-
Set offset for the row per Column Family.
- setRowOffsetPerColumnFamily(int) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set offset for the row per Column Family.
- setRowPrefixFilter(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set a filter (using stopRow and startRow) so the result set only contains rows where the
rowKey starts with the specified prefix.
- setRowProcessorClassName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
required string row_processor_class_name = 1;
- setRowProcessorClassNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
required string row_processor_class_name = 1;
- setRowProcessorInitializerMessage(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional bytes row_processor_initializer_message = 3;
- setRowProcessorInitializerMessageName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional string row_processor_initializer_message_name = 2;
- setRowProcessorInitializerMessageNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessRequest.Builder
-
optional string row_processor_initializer_message_name = 2;
- setRowProcessorResult(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.ProcessResponse.Builder
-
required bytes row_processor_result = 1;
- setRowRangeList(int, FilterProtos.RowRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- setRowRangeList(int, FilterProtos.RowRange.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- setRows(int, CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- setRows(int, CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- setRows(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
row keys
- setRows(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
row keys
- setRows(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
row keys
- setRows(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
row keys
- setRowsDeleted(long) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
required uint64 rowsDeleted = 1;
- setRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- setRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- setRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- setRowsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setRowTreeDepth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setRPC(String, Object[], long) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- setRPC(String, Object[], long) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Tells this instance that it is monitoring a new RPC call.
- setRPCPacket(Message) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
-
- setRPCPacket(Message) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
-
Gives this instance a reference to the protobuf received by the RPC, so
that it can later compute its size if asked for it.
- setRpcTimeout(int) - Method in class org.apache.hadoop.hbase.client.HTable
-
- setRpcVersion(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master.Builder
-
optional uint32 rpc_version = 2;
- setRpcVersion(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
optional uint32 rpc_version = 2;
- setRunner(Runnable) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- setSaslTokenResponse(ByteBuffer) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- setScan(ClientProtos.Scan) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required .Scan scan = 1;
- setScan(ClientProtos.Scan.Builder) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
required .Scan scan = 1;
- setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
Sets the scan defining the actual details like columns etc.
- setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
Sets the scan defining the actual details like columns etc.
- setScan(Scan) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
-
Sets the scan defining the actual details like columns etc.
- setScan(ClientProtos.Scan) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required .Scan scan = 2;
- setScan(ClientProtos.Scan.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateRequest.Builder
-
required .Scan scan = 2;
- setScan(ClientProtos.Scan) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .Scan scan = 2;
- setScan(ClientProtos.Scan.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional .Scan scan = 2;
- setScan(TScan) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Scan instance
- setScan(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
the scan object to get a Scanner for
- setScan(TScan) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
the scan object to get a Scanner for
- setScanIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- setScanIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- setScanIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- setScanMetricsEnabled(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
- setScannerCaching(int) - Method in class org.apache.hadoop.hbase.client.HTable
-
- setScannerCaching(JobConf, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
Sets the number of rows to return and cache with each scanner iteration.
- setScannerCaching(Job, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Sets the number of rows to return and cache with each scanner iteration.
- setScannerCallableFactory(ClientSmallScanner.SmallScannerCallableFactory) - Method in class org.apache.hadoop.hbase.client.ClientSmallReversedScanner
-
- setScannerCallableFactory(ClientSmallScanner.SmallScannerCallableFactory) - Method in class org.apache.hadoop.hbase.client.ClientSmallScanner
-
- setScannerId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanRequest.Builder
-
optional uint64 scanner_id = 3;
- setScannerId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional uint64 scanner_id = 2;
- setScannerId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
the Id of the Scanner to close *
- setScannerId(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
the Id of the Scanner to return rows from.
- setScannerIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- setScannerIdIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- setScanQueryMatcher(ScanQueryMatcher) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- setScanResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RunCatalogScanResponse.Builder
-
optional int32 scan_result = 1;
- setScans(List<Scan>) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
Allows subclasses to set the list of
Scan
objects.
- setScope(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setScope(QuotaProtos.QuotaScope) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
optional .QuotaScope scope = 4 [default = MACHINE];
- setScopes(int, WALProtos.FamilyScope) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- setScopes(int, WALProtos.FamilyScope.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- setScopes(NavigableMap<byte[], Integer>) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
- setScopeType(WALProtos.ScopeType) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FamilyScope.Builder
-
required .ScopeType scope_type = 2;
- setSecond(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.BytesBytesPair.Builder
-
required bytes second = 2;
- setSecond(T2) - Method in class org.apache.hadoop.hbase.util.Pair
-
Replace the second element of the pair.
- setSecond(B) - Method in class org.apache.hadoop.hbase.util.Triple
-
- setSecondPart(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
optional bytes second_part = 2;
- setSecretManager(SecretManager<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- setSecurityEnabled(boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setSequenceFilter(long) - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
sets the region by which output will be filtered
- setSequenceId(Cell, long) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Sets the given seqId to the cell.
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.KeyValue
-
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.StoreSequenceId.Builder
-
required uint64 sequence_id = 2;
- setSequenceID(long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- setSequenceId(long) - Method in interface org.apache.hadoop.hbase.SettableSequenceId
-
Sets with the given seqId.
- setSequenceId(long) - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- setSequenceNumber(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
optional int64 sequence_number = 6;
- setSerializedComparator(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.Comparator.Builder
-
optional bytes serialized_comparator = 2;
- setSerializedFilter(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.Filter.Builder
-
optional bytes serialized_filter = 2;
- setServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerName server = 1;
- setServer(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerName server = 1;
- setServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
required .ServerName server = 1;
- setServer(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerReportRequest.Builder
-
required .ServerName server = 1;
- setServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
required .ServerName server = 1;
- setServer(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
required .ServerName server = 1;
- setServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required .ServerName server = 1;
- setServer(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRSFatalErrorRequest.Builder
-
required .ServerName server = 1;
- setServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional .ServerName server = 6;
- setServer(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
optional .ServerName server = 6;
- setServer(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
required .ServerName server = 1;
- setServer(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
required .ServerName server = 1;
- setServerCurrentTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
required uint64 server_current_time = 3;
- setServerHasMoreResults(boolean) - Method in class org.apache.hadoop.hbase.client.ScannerCallable
-
- setServerInfo(AdminProtos.ServerInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
required .ServerInfo server_info = 1;
- setServerInfo(AdminProtos.ServerInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetServerInfoResponse.Builder
-
required .ServerInfo server_info = 1;
- setServerLoad(ClusterStatusProtos.ServerLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerLoad server_load = 2;
- setServerLoad(ClusterStatusProtos.ServerLoad.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.LiveServerInfo.Builder
-
required .ServerLoad server_load = 2;
- setServerManager(ServerManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setServerManager(ServerManager) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setServerName(ServerName) - Method in interface org.apache.hadoop.hbase.coordination.OpenRegionCoordination.OpenRegionDetails
-
Sets server name on which opening operation is running.
- setServerName(ServerName) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
-
- setServerName(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
required .ServerName server_name = 1;
- setServerName(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
required .ServerName server_name = 1;
- setServerName(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required .ServerName server_name = 4;
- setServerName(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.RegionTransition.Builder
-
required .ServerName server_name = 4;
- setServerName(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
required .ServerName server_name = 2;
- setServerName(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
required .ServerName server_name = 2;
- setServerName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setServerName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setServerNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl.ImplData
-
- setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.MasterStatusTmpl
-
- setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl.ImplData
-
- setServers(List<ServerName>) - Method in class org.apache.hadoop.hbase.tmpl.master.RegionServerListTmpl
-
- setServerSideHConnectionRetries(Configuration, String, Log) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
Internal method, do not use.
- setServerSideHConnectionRetriesConfig(Configuration, String, Log) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Changes the configuration to set the number of retries needed when using HConnection
internally, e.g.
- setServerStartCode(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional uint64 serverStartCode = 5;
- setServerStartCode(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
optional uint64 serverStartCode = 2;
- setServerStartCode(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
required uint64 server_start_code = 2;
- setServerVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.VersionModel
-
- setServerVersion(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string serverVersion = 4;
- setServerVersionBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.VersionMessage.Version.Builder
-
optional string serverVersion = 4;
- setService(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.Token.Builder
-
optional bytes service = 3;
- setService(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional string service = 4;
- setServiceBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken.Builder
-
optional string service = 4;
- setServiceCall(ClientProtos.CoprocessorServiceCall) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .CoprocessorServiceCall service_call = 4;
- setServiceCall(ClientProtos.CoprocessorServiceCall.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Action.Builder
-
optional .CoprocessorServiceCall service_call = 4;
- setServiceName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required string service_name = 2;
- setServiceName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string service_name = 2;
- setServiceNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceCall.Builder
-
required string service_name = 2;
- setServiceNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional string service_name = 2;
- setServiceResult(ClientProtos.CoprocessorServiceResult) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .CoprocessorServiceResult service_result = 4;
- setServiceResult(ClientProtos.CoprocessorServiceResult.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ResultOrException.Builder
-
optional .CoprocessorServiceResult service_result = 4;
- setShare(float) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
optional float share = 3;
- setSidelineBigOverlaps(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setSidelineDir(String) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- setSignature(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
required string signature = 1;
- setSignatureBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
required string signature = 1;
- setSingleColumnValueFilter(FilterProtos.SingleColumnValueFilter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- setSingleColumnValueFilter(FilterProtos.SingleColumnValueFilter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter.Builder
-
required .SingleColumnValueFilter single_column_value_filter = 1;
- setSize(int) - Method in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.ReplicateContext
-
- setSizeLimit(ScannerContext.LimitScope, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
-
- setSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint32 sizeOfLogQueue = 3;
- setSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- setSizeOfLogQueue(int) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- setSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- setSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Set the size of the log queue
- setSkipChecks(boolean) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- setSkipTableStateCheck(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required bool skip_table_state_check = 3;
- setSkipTableStateCheck(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required bool skip_table_state_check = 3;
- setSleepInterval(long) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- setSlop(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- setSlop(Configuration) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- setSmall(boolean) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set whether this scan is a small scan
- setSmall(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bool small = 14;
- setSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- setSnapshot(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- setSnapshot(HBaseProtos.ProcedureDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
optional .ProcedureDescription snapshot = 2;
- setSnapshot(HBaseProtos.ProcedureDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse.Builder
-
optional .ProcedureDescription snapshot = 2;
- setSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- setSnapshot(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- setSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- setSnapshot(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest.Builder
-
optional .SnapshotDescription snapshot = 1;
- setSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
optional .SnapshotDescription snapshot = 2;
- setSnapshot(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse.Builder
-
optional .SnapshotDescription snapshot = 2;
- setSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- setSnapshot(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- setSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- setSnapshot(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest.Builder
-
required .SnapshotDescription snapshot = 1;
- setSnapshotHandlerForTesting(TableName, SnapshotSentinel) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Set the handler for the current snapshot
- setSnapshots(int, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- setSnapshots(int, HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- setSocketSendBufSize(int) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Sets the socket buffer size used for responding to RPCs.
- setSocketSendBufSize(int) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- setSoftLimit(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
optional uint64 soft_limit = 2;
- setSortColumns(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setSortColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setSortedColumns(List<TColumn>) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setSortedColumnsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- setSortedPrefixes(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
repeated bytes sorted_prefixes = 1;
- setSource(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional string source = 1;
- setSource(MetricsThriftServerSource) - Method in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- setSourceBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage.Builder
-
optional string source = 1;
- setSpec(HBaseProtos.RegionSpecifier) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionSpecifier spec = 1;
- setSpec(HBaseProtos.RegionSpecifier.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition.Builder
-
required .RegionSpecifier spec = 1;
- setSplit(boolean) - Method in class org.apache.hadoop.hbase.HRegionInfo
-
- setSplit(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bool split = 6;
- setSplitkey(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference.Builder
-
required bytes splitkey = 1;
- setSplitKeys(int, ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
repeated bytes split_keys = 2;
- setSplitPoint(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest.Builder
-
optional bytes split_point = 2;
- setSrcChecksum(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string src_checksum = 6;
- setSrcChecksumBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string src_checksum = 6;
- setStackId(int, int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
repeated uint32 stack_id = 7;
- setStackIndexes(List<Integer>) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called on store load to initialize the Procedure internals after
the creation/deserialization.
- setStackTrace(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string stack_trace = 2;
- setStackTraceBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse.Builder
-
optional string stack_trace = 2;
- setStale(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
optional bool stale = 4 [default = false];
- setStale(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional bool stale = 6;
- setStamp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
optional uint64 stamp = 3;
- setStartAndPrefix(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
the prefix (and thus start row) of the keys you want
- setStartAndPrefix(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setStartAndPrefixIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setStartCode(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName.Builder
-
optional uint64 start_code = 3;
- setStartCode(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
- setStartCode(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
optional int64 startCode = 2;
- setStartDate(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
required string start_date = 1;
- setStartDateBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp.Builder
-
required string start_date = 1;
- setStartId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
required uint64 start_id = 1;
- setStartKey(Configuration, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- setStartKey(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
optional bytes start_key = 3;
- setStartKey(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.TableRegionModel
-
- setStartKey(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region.Builder
-
optional bytes startKey = 2;
- setStartKey(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setStartKey(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setStartKeyIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the start row of the scan.
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
-
- setStartRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bytes start_row = 3;
- setStartRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bytes start_row = 1;
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setStartRow(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional bytes startRow = 1;
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Starting row in table to scan.
- setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Starting row in table to scan.
- setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Starting row in table to scan.
- setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Starting row in table to scan.
- setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setStartRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setStartRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setStartRowInclusive(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bool start_row_inclusive = 2;
- setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setStartRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setStartTime(long) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called on store load to initialize the Procedure internals after
the creation/deserialization.
- setStartTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
optional uint64 start_time = 2;
- setStartTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required uint64 start_time = 4;
- setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
optional int64 startTime = 5;
- setStartTime(long) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- setState(ProcedureProtos.ProcedureState) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setState(ClusterStatusProtos.RegionState.State) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.Builder
-
required .RegionState.State state = 2;
- setState(MasterProtos.GetProcedureResultResponse.State) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse.Builder
-
required .GetProcedureResultResponse.State state = 1;
- setState(ProcedureProtos.ProcedureState) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
required .ProcedureState state = 6;
- setState(int, int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
repeated uint32 state = 1;
- setState(ClusterStatusProtos.RegionState.State) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer.Builder
-
optional .RegionState.State state = 3;
- setState(ZooKeeperProtos.ReplicationState.State) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.Builder
-
required .ReplicationState.State state = 1;
- setState(ZooKeeperProtos.SplitLogTask.State) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.Builder
-
required .SplitLogTask.State state = 1;
- setState(ZooKeeperProtos.Table.State) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.Builder
-
required .Table.State state = 1 [default = ENABLED];
- setStateData(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional bytes state_data = 12;
- setStatistics(ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.Result
-
Set load information about the region to the information about the result
- setStatisticTracker(ServerStatisticTracker) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerFactory
-
Set the tracker that should be used for tracking statistics about the server
- setStatus(MonitoredRPCHandler) - Method in class org.apache.hadoop.hbase.ipc.CallRunner
-
- setStatus(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- setStatus(int) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Set the stop row.
- setStopRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional bytes stop_row = 4;
- setStopRow(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bytes stop_row = 3;
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
row to stop scanning on.
- setStopRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
row to stop scanning on.
- setStopRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setStopRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setStopRow(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setStopRow(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setStopRowInclusive(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange.Builder
-
optional bool stop_row_inclusive = 4;
- setStopRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setStopRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setStopRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setStopRowIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setStopRowKey(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter.Builder
-
optional bytes stop_row_key = 1;
- setStoragePolicy(FileSystem, Configuration, Path, String, String) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets storage policy for given path according to config setting.
- setStoreCompleteSequenceId(int, ClusterStatusProtos.StoreSequenceId) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- setStoreCompleteSequenceId(int, ClusterStatusProtos.StoreSequenceId.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- setStoreFile(int, String) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
repeated string store_file = 1;
- setStoreFile(int, String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
repeated string store_file = 3;
- setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 storefile_index_size_MB = 7;
- setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setStorefileIndexSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 storefileIndexSizeMB = 6;
- setStorefiles(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 storefiles = 3;
- setStoreFiles(int, SnapshotProtos.SnapshotRegionManifest.StoreFile) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- setStoreFiles(int, SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- setStorefiles(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setStorefiles(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 storefiles = 3;
- setStorefileSizeMB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 storefile_size_MB = 5;
- setStorefileSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setStorefileSizeMB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 storefileSizeMB = 4;
- setStoreFlushes(int, WALProtos.FlushDescriptor.StoreFlushDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- setStoreFlushes(int, WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- setStoreHomeDir(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required string store_home_dir = 6;
- setStoreHomeDir(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
required string store_home_dir = 2;
- setStoreHomeDir(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
required string store_home_dir = 2;
- setStoreHomeDirBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required string store_home_dir = 6;
- setStoreHomeDirBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
required string store_home_dir = 2;
- setStoreHomeDirBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
required string store_home_dir = 2;
- setStoreLastFlushedSequenceId(int, ClusterStatusProtos.StoreSequenceId) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- setStoreLastFlushedSequenceId(int, ClusterStatusProtos.StoreSequenceId.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- setStoreLimit(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional uint32 store_limit = 8;
- setStoreLimit(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 store_limit = 11;
- setStoreOffset(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional uint32 store_offset = 9;
- setStoreOffset(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional uint32 store_offset = 12;
- setStores(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 stores = 2;
- setStores(int, WALProtos.StoreDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- setStores(int, WALProtos.StoreDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- setStores(int, WALProtos.StoreDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- setStores(int, WALProtos.StoreDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- setStores(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setStores(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 stores = 2;
- setStoreSequenceId(int, ClusterStatusProtos.StoreSequenceId) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- setStoreSequenceId(int, ClusterStatusProtos.StoreSequenceId.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- setStoreUncompressedSizeMB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 store_uncompressed_size_MB = 4;
- setStub(AdminProtos.AdminService.BlockingInterface) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- setSubstr(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
required string substr = 1;
- setSubstrBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator.Builder
-
required string substr = 1;
- setSuccess(Message, CellScanner) - Method in class org.apache.hadoop.hbase.ipc.AsyncCall
-
Set success with a cellBlockScanner
- setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- setSuccess(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- setSuccess(Map<ByteBuffer, ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- setSuccess(TRegionInfo) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- setSuccess(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- setSuccess(List<TRegionInfo>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- setSuccess(List<TCell>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setSuccess(List<TRowResult>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- setSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- setSuccess(List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- setSuccess(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- setSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- setSuccess(List<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- setSuccess(List<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- setSuccess(List<TResult>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- setSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- setSuccess(int) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- setSuccessIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- setSuffixLengthVariance(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setSynchronous(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest.Builder
-
optional bool synchronous = 2;
- setTable(Table) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
-
- setTable(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional string table = 2;
- setTable(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .TableSchema table = 3;
- setTable(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
optional .TableSchema table = 3;
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
the table to append the value on
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
to check in and delete from
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
to check in and put to
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
the table to delete from
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
the table to delete from
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
the table to check on
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
the table to get from
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
the table to get from
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
the table to get the Scanner for
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
the table to increment the value on
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
table to apply the mutations
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
the table to get the Scanner for
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
the table to put data in
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- setTable(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
the table to put data in
- setTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- setTableBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional string table = 2;
- setTableFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the table filter regex
- setTableGroupPermissions(String, TableName, List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Overwrites the existing permission set for a group and triggers an update
for zookeeper synchronization.
- setTableInfo(HBaseFsck.TableInfo) - Method in interface org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandler
-
Set the TableInfo used by all HRegionInfos fabricated by other callbacks
- setTableInfo(HBaseFsck.TableInfo) - Method in class org.apache.hadoop.hbase.util.hbck.TableIntegrityErrorHandlerImpl
-
Set the TableInfo used by all HRegionInfos fabricated by other callbacks
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- setTableIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional .TableName table_name = 2;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional .TableName table_name = 2;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
optional .TableName table_name = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
optional .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
optional .TableName table_name = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .TableName table_name = 2;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableName table_name = 3;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableName table_name = 3;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.AddColumnRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteColumnRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteTableRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DisableTableRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.EnableTableRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusRequest.Builder
-
required .TableName table_name = 1;
- setTableName(int, HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- setTableName(int, HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MajorCompactionTimestampRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyColumnRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .TableName table_name = 4;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .TableName table_name = 4;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
required .TableName tableName = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.TruncateTableRequest.Builder
-
required .TableName tableName = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.PrepareBulkLoadRequest.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
required .TableName table_name = 1;
- setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
required bytes table_name = 1;
- setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
required bytes table_name = 2;
- setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
required bytes table_name = 2;
- setTableName(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required bytes table_name = 2;
- setTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .TableName table_name = 1;
- setTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional .TableName table_name = 1;
- setTableName(TableName) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
name of table to create
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
name of table to delete
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
name of the table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
name of the table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
table name
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
name of the table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
name of the table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
table name
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
name of the table to check
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setTableName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
name of table
- setTableName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- setTableNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setTableNameOrRegionName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- setTableNameOrRegionName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- setTableNameOrRegionName(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- setTableNameOrRegionName(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- setTableNameOrRegionNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- setTableNameOrRegionNameIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- setTableNames(int, HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- setTableNames(int, HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- setTableNames(int, HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- setTableNames(int, HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- setTablePermission(AccessControlProtos.TablePermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .TablePermission table_permission = 4;
- setTablePermission(AccessControlProtos.TablePermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
optional .TablePermission table_permission = 4;
- setTableQuota(TableName, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
-
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
-
- setTableRecordReader(TableRecordReader) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
-
- setTables(List<TableModel>) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
- setTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .TableSchema table_schema = 2;
- setTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .TableSchema table_schema = 2;
- setTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableSchema table_schema = 4;
- setTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
optional .TableSchema table_schema = 4;
- setTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
required .TableSchema table_schema = 1;
- setTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
required .TableSchema table_schema = 1;
- setTableSchema(int, HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- setTableSchema(int, HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- setTableSchema(int, HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- setTableSchema(int, HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- setTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableSchema table_schema = 2;
- setTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ModifyTableRequest.Builder
-
required .TableSchema table_schema = 2;
- setTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
required .TableSchema table_schema = 1;
- setTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
required .TableSchema table_schema = 1;
- SettableSequenceId - Interface in org.apache.hadoop.hbase
-
Using this Interface one can mark a Cell as Sequence stampable.
- setTableState(TableName, ZooKeeperProtos.Table.State) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
Sets the table into desired state.
- setTableState(TableName, ZooKeeperProtos.Table.State) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Sets table state in ZK.
- setTableStateIfInStates(TableName, ZooKeeperProtos.Table.State, ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
Sets the specified table into the newState, but only if the table is already in
one of the possibleCurrentStates (otherwise no operation is performed).
- setTableStateIfInStates(TableName, ZooKeeperProtos.Table.State, ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Checks and sets table state in ZK.
- setTableStateIfNotInStates(TableName, ZooKeeperProtos.Table.State, ZooKeeperProtos.Table.State...) - Method in interface org.apache.hadoop.hbase.TableStateManager
-
Sets the specified table into the newState, but only if the table is NOT in
one of the possibleCurrentStates (otherwise no operation is performed).
- setTableStateIfNotInStates(TableName, ZooKeeperProtos.Table.State, ZooKeeperProtos.Table.State...) - Method in class org.apache.hadoop.hbase.zookeeper.ZKTableStateManager
-
Checks and sets table state in ZK.
- setTableStateToDisabled(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Mark table state to Disabled
- setTableStateToDisabling(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Mark table state to Disabling
- setTableStateToEnabled(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
Mark table state to Enabled
- setTableStateToEnabling(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
Mark table state to Enabling
- SettableTimestamp - Interface in org.apache.hadoop.hbase
-
Using this Interface one can mark a Cell as timestamp changeable.
- setTableUserPermissions(String, TableName, List<TablePermission>) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Overwrites the existing permission set for a given user for a table, and
triggers an update for zookeeper synchronization.
- setTagCompressionContext(TagCompressionContext) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultDecodingContext
-
- setTagCompressionContext(TagCompressionContext) - Method in class org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext
-
- setTags(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes tags = 7;
- setTags(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional bytes tags = 7;
- setTags(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional bytes tags = 5;
- setTags(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setTags(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setTagsIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setTagsOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setTargetTableName(String[]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
-
- setTaskMonitor(TaskMonitor) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl.ImplData
-
- setTaskMonitor(TaskMonitor) - Method in class org.apache.hadoop.hbase.tmpl.common.TaskMonitorTmpl
-
- setTaskNode(String) - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination.ZkSplitTaskDetails
-
- setTEST_FORCE_REFRESH(boolean) - Static method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- setThird(C) - Method in class org.apache.hadoop.hbase.util.Triple
-
- setThreadId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.TableLock.Builder
-
optional int64 thread_id = 3;
- setThreads(int, int) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Set the min, max number of worker threads (simultaneous connections).
- setThrottle(QuotaProtos.ThrottleRequest) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .ThrottleRequest throttle = 7;
- setThrottle(QuotaProtos.ThrottleRequest.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional .ThrottleRequest throttle = 7;
- setThrottle(QuotaProtos.Throttle) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
optional .Throttle throttle = 2;
- setThrottle(QuotaProtos.Throttle.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Quotas.Builder
-
optional .Throttle throttle = 2;
- setTickTime(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- setTimedQuota(QuotaProtos.TimedQuota) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
optional .TimedQuota timed_quota = 2;
- setTimedQuota(QuotaProtos.TimedQuota.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
optional .TimedQuota timed_quota = 2;
- setTimeLag(long) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
We are interested in only those tables that have not changed their state in
hbase:meta during the last few seconds specified by hbase.admin.fsck.timelag
- setTimeLimit(ScannerContext.LimitScope, long) - Method in class org.apache.hadoop.hbase.regionserver.ScannerContext.Builder
-
- setTimeout(int) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setTimeout(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
optional uint32 timeout = 9;
- setTimeoutFailure() - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Get
-
Get versions of columns only within the specified timestamp range,
[minStamp, maxStamp).
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Increment
-
Sets the TimeRange to be used on the Get for this increment.
- setTimeRange(long, long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get versions of columns only within the specified timestamp range,
[minStamp, maxStamp).
- setTimeRange(HBaseProtos.TimeRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .TimeRange time_range = 5;
- setTimeRange(HBaseProtos.TimeRange.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
optional .TimeRange time_range = 5;
- setTimeRange(HBaseProtos.TimeRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .TimeRange time_range = 7;
- setTimeRange(HBaseProtos.TimeRange.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional .TimeRange time_range = 7;
- setTimeRange(HBaseProtos.TimeRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .TimeRange time_range = 6;
- setTimeRange(HBaseProtos.TimeRange.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
optional .TimeRange time_range = 6;
- setTimeRange(TTimeRange) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setTimeRange(TTimeRange) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setTimeRangeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setTimeRangeIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- setTimeRangeTracker(TimeRangeTracker) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
Set TimeRangeTracker
- setTimestamp(Cell, long) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Sets the given timestamp to the cell.
- setTimestamp(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.CellUtil
-
Sets the given timestamp to the cell.
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Set the timestamp of the delete.
- setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Get
-
Get versions of columns with the specified timestamp.
- setTimeStamp(long) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get versions of columns with the specified timestamp.
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.Builder
-
optional uint64 timestamp = 3;
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.KeyValue
-
- setTimestamp(byte[], int) - Method in class org.apache.hadoop.hbase.KeyValue
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.master.RegionState
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional uint64 timestamp = 4;
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional uint64 timestamp = 4;
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
optional uint64 timestamp = 4;
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional uint64 timestamp = 3;
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell.Builder
-
optional int64 timestamp = 3;
- setTimestamp(long) - Method in interface org.apache.hadoop.hbase.SettableTimestamp
-
Sets with the given timestamp.
- setTimestamp(byte[], int) - Method in interface org.apache.hadoop.hbase.SettableTimestamp
-
Sets with the given timestamp.
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- setTimestamp(byte[], int) - Method in class org.apache.hadoop.hbase.TagRewriteCell
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
timestamp
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setTimestamp(long) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setTimestampDeltaWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setTimestampDiffSize(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setTimestampFields(LongEncoder) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setTimestampIndexWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- setTimestampIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- setTimeStampOfLastShippedOp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource.Builder
-
required uint64 timeStampOfLastShippedOp = 4;
- setTimestamps(int, long) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
repeated int64 timestamps = 1 [packed = true];
- setTimeStampsOfLastAppliedOp(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink.Builder
-
required uint64 timeStampsOfLastAppliedOp = 2;
- setTimeToLive(int) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setTimeToLive(int) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setTimeToLiveIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- setTimeUnit(HBaseProtos.TimeUnit) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota.Builder
-
required .TimeUnit time_unit = 1;
- setTimeUnit(TimeUnit) - Method in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
-
- setTo(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeRange.Builder
-
optional uint64 to = 2;
- setToken(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- setToken(AuthenticationProtos.Token) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
optional .Token token = 1;
- setToken(AuthenticationProtos.Token.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.GetAuthenticationTokenResponse.Builder
-
optional .Token token = 1;
- setTokenBytes(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.column.ColumnNodeWriter
-
- setTokenOffset(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- setTotalCompactingKVs(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 total_compacting_KVs = 10;
- setTotalCompactingKVs(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setTotalCompactingKVs(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 totalCompactingKVs = 12;
- setTotalNumberOfRequests(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint64 total_number_of_requests = 2;
- setTotalRegions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
optional uint32 total_regions = 2;
- setTotalStaticBloomSizeKB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 total_static_bloom_size_KB = 14;
- setTotalStaticBloomSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setTotalStaticBloomSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 totalStaticBloomSizeKB = 11;
- setTotalStaticIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint32 total_static_index_size_KB = 13;
- setTotalStaticIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setTotalStaticIndexSizeKB(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int32 totalStaticIndexSizeKB = 10;
- setTotalUncompressedBytes(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setTotalUncompressedBytes(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 total_uncompressed_bytes = 4;
- setTrace(int, ErrorHandlingProtos.StackTraceElementMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- setTrace(int, ErrorHandlingProtos.StackTraceElementMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- setTraceId(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.TracingProtos.RPCTInfo.Builder
-
optional int64 trace_id = 1;
- setTraceInfo(TracingProtos.RPCTInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .RPCTInfo trace_info = 2;
- setTraceInfo(TracingProtos.RPCTInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.RequestHeader.Builder
-
optional .RPCTInfo trace_info = 2;
- setTrackerPos(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
required uint64 tracker_pos = 2;
- setTransition(int, RegionServerStatusProtos.RegionStateTransition) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- setTransition(int, RegionServerStatusProtos.RegionStateTransition.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- setTransitionCode(RegionServerStatusProtos.RegionStateTransition.TransitionCode) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
required .RegionStateTransition.TransitionCode transition_code = 1;
- setTransitionInZK(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional bool transition_in_ZK = 3 [default = true];
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Append
-
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Delete
-
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Increment
-
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Mutation
-
Set the TTL desired for the result of the mutation, in milliseconds.
- setTTL(long) - Method in class org.apache.hadoop.hbase.client.Put
-
- setTtl(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
optional uint32 ttl = 4;
- setTtl(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
optional int32 ttl = 3;
- setType(AccessControlProtos.Permission.Type) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsRequest.Builder
-
optional .Permission.Type type = 1;
- setType(AccessControlProtos.Permission.Type) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Builder
-
required .Permission.Type type = 1;
- setType(HBaseProtos.RegionSpecifier.RegionSpecifierType) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
required .RegionSpecifier.RegionSpecifierType type = 1;
- setType(HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional .SnapshotDescription.Type type = 4 [default = FLUSH];
- setType(ProcedureProtos.ProcedureWALEntry.Type) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
required .ProcedureWALEntry.Type type = 1;
- setType(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint32 type = 2;
- setType(QuotaProtos.ThrottleType) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.ThrottleRequest.Builder
-
optional .ThrottleType type = 1;
- setType(SnapshotProtos.SnapshotFileInfo.Type) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
required .SnapshotFileInfo.Type type = 1;
- setUnassigned() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- setUnblockedFlushCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
-
- setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.hadoop.hbase.util.HasThread
-
- setUncompressedDataIndexSize(long) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
-
- setUncompressedDataIndexSize(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto.Builder
-
optional uint64 uncompressed_data_index_size = 3;
- setUnmodifiedTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- setUnmodifiedTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- setUnmodifiedTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- setUnmodifiedTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- setUnmodifiedTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- setUnmodifiedTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
optional .TableSchema unmodified_table_schema = 4;
- setUnmodifiedTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
optional .TableSchema unmodified_table_schema = 2;
- setUnmodifiedTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
optional .TableSchema unmodified_table_schema = 2;
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.Import.KeyValueImporter
-
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.IndexBuilder.Map
-
- setup(Reducer<ImmutableBytesWritable, Text, ImmutableBytesWritable, KeyValue>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
Handles initializing this class with objects specific to it (i.e., the parser).
- setup(Mapper<LongWritable, Text, ImmutableBytesWritable, Put>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Handles initializing this class with objects specific to it (i.e., the parser).
- setup(Mapper<LongWritable, Text, ImmutableBytesWritable, Text>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
Handles initializing this class with objects specific to it (i.e., the parser).
- setup(Mapper<WALKey, WALEdit, ImmutableBytesWritable, Mutation>.Context) - Method in class org.apache.hadoop.hbase.mapreduce.WALPlayer.WALMapper
-
- setup(RegionServerServices) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputController
-
Setup controller for the given region server.
- setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- setup(RegionServerServices) - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- setupClusterConnection() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Setup our cluster connection if not already initialized.
- setupConnection() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
-
- setUpdated(int, long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 updated = 2;
- setUpdateInfo(int, AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- setUpdateInfo(int, AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- setupIOstreams() - Method in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
-
- setupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- setupMasterlessConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Setup the connection class, so that it will not depend on master being online.
- setupRegionReplicaReplication(Configuration) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Create replication peer for replicating to region replicas if needed.
- setupSetQuotaRequest(MasterProtos.SetQuotaRequest.Builder) - Method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
Called by toSetQuotaRequestProto() the subclass should implement this method to set the
specific SetQuotaRequest properties.
- setupShortCircuitRead(Configuration) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Do our short circuit read setup.
- setupTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- setUrl(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string url = 2;
- setUrlBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string url = 2;
- setUsedHeapMB(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
optional uint32 used_heap_MB = 3;
- setUser(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UserPermission.Builder
-
required bytes user = 1;
- setUser(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
required bytes user = 1;
- setUser(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string user = 4;
- setUser(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsRequest.Builder
-
required bytes user = 1;
- setUser(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
required bytes user = 1;
- setUser(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
required bytes user = 1;
- setUser(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
required bytes user = 1;
- setUserAuths(int, VisibilityLabelsProtos.UserAuthorizations) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- setUserAuths(int, VisibilityLabelsProtos.UserAuthorizations.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- setUserBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string user = 4;
- setUserFilter(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Set the user filter regex
- setUserGroup(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string user_group = 2;
- setUserGroupBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string user_group = 2;
- setUserInfo(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyColumnFamilyStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
required .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .UserInformation user_info = 1;
- setUserInfo(RPCProtos.UserInformation.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .UserInformation user_info = 1;
- setUsername(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier.Builder
-
required bytes username = 2;
- setUsername(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
optional string username = 1;
- setUserName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string user_name = 1;
- setUsernameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse.Builder
-
optional string username = 1;
- setUserNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetQuotaRequest.Builder
-
optional string user_name = 1;
- setUsernameConfKey(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
- setUserPermission(int, AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- setUserPermission(int, AccessControlProtos.UserPermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- setUserPermission(AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
required .UserPermission user_permission = 1;
- setUserPermission(AccessControlProtos.UserPermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GrantRequest.Builder
-
required .UserPermission user_permission = 1;
- setUserPermission(AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
required .UserPermission user_permission = 1;
- setUserPermission(AccessControlProtos.UserPermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.RevokeRequest.Builder
-
required .UserPermission user_permission = 1;
- setUserPermissions(int, AccessControlProtos.UsersAndPermissions.UserPermissions) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- setUserPermissions(int, AccessControlProtos.UsersAndPermissions.UserPermissions.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- setUserProviderForTesting(Configuration, Class<? extends UserProvider>) - Static method in class org.apache.hadoop.hbase.security.UserProvider
-
Set the
UserProvider
in the given configuration that should be instantiated
- setUserQuota(String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setUserQuota(String, TableName, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setUserQuota(String, String, MasterProtos.SetQuotaRequest) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- setUseThisHostnameInstead(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
optional string use_this_hostname_instead = 4;
- setUseThisHostnameInsteadBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupRequest.Builder
-
optional string use_this_hostname_instead = 4;
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- setValue(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setValue(ImmutableBytesWritable, ImmutableBytesWritable) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setValue(String, String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
- setValue(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.Cell.Builder
-
optional bytes value = 6;
- setValue(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue.Builder
-
optional bytes value = 6;
- setValue(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .NameBytesPair value = 2;
- setValue(HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResponse.Builder
-
required .NameBytesPair value = 2;
- setValue(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
optional .NameBytesPair value = 1;
- setValue(HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.CoprocessorServiceResult.Builder
-
optional .NameBytesPair value = 1;
- setValue(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder
-
optional bytes value = 2;
- setValue(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.ByteArrayComparable.Builder
-
optional bytes value = 1;
- setValue(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameBytesPair.Builder
-
optional bytes value = 2;
- setValue(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameInt64Pair.Builder
-
optional int64 value = 2;
- setValue(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
required string value = 2;
- setValue(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionSpecifier.Builder
-
required bytes value = 2;
- setValue(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsCatalogJanitorEnabledResponse.Builder
-
required bool value = 1;
- setValue(V) - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
-
Set the value of this entry.
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.CellModel
-
- setValue(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
required string value = 2;
- setValue(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
required string value = 2;
- setValue(long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
amount to increment by
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
the expected value for the column parameter, if not
provided the check is for the non-existence of the
column in question
- setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
the expected value, if not provided the
check is for the non-existence of the
column in question
- setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setValue(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
the expected value, if not provided the
check is for the non-existence of the
column in question
- setValue(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setValue(long) - Method in class org.apache.hadoop.hbase.util.ManualEnvironmentEdge
-
- setValueBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NameStringPair.Builder
-
required string value = 2;
- setValueBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Attribute.Builder
-
required string value = 2;
- setValueBytes(ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Attribute.Builder
-
required string value = 2;
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- setValueIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- setValueLength(int) - Method in class org.apache.hadoop.hbase.util.test.RedundantKVGenerator
-
- setValueLengthWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setValueOffsetWidth(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setValues(int, CellMessage.Cell) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- setValues(int, CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- setValues(List<ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- setValuesIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- setVersion(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- setVersion(int) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
-
- setVersion(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
required string version = 1;
- setVersion(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Builder
-
optional int32 version = 5;
- setVersion(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALHeader.Builder
-
required uint32 version = 1;
- setVersion(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALTrailer.Builder
-
required uint32 version = 1;
- setVersion(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string version = 1;
- setVersion(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
optional int32 version = 1;
- setVersion(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
- setVersion(byte) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setVersion(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets version of file system
- setVersion(FileSystem, Path, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets version of file system
- setVersion(FileSystem, Path, String, int, int) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Sets version of file system
- setVersionBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.HBaseVersionFileContent.Builder
-
required string version = 1;
- setVersionBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo.Builder
-
required string version = 1;
- setVersionInfo(RPCProtos.VersionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .VersionInfo version_info = 5;
- setVersionInfo(RPCProtos.VersionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ConnectionHeader.Builder
-
optional .VersionInfo version_info = 5;
- setVersionIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- setVersionOfClosingNode(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest.Builder
-
optional uint32 version_of_closing_node = 2;
- setVersionOfOfflineNode(int) - Method in class org.apache.hadoop.hbase.coordination.ZkOpenRegionCoordination.ZkOpenRegionDetails
-
- setVersionOfOfflineNode(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
optional uint32 version_of_offline_node = 2;
- setVersionsDeleted(long) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteResponse.Builder
-
optional uint64 versionsDeleted = 2;
- setVictimCache(BlockCache) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- setVisLabel(int, VisibilityLabelsProtos.VisibilityLabel) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- setVisLabel(int, VisibilityLabelsProtos.VisibilityLabel.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- setWalEdit(int, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
Sets the walEdit for the operation(Mutation) at the specified position.
- setWalName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string wal_name = 5;
- setWalNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string wal_name = 5;
- setWalServer(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string wal_server = 4;
- setWalServerBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotFileInfo.Builder
-
optional string wal_server = 4;
- setWatchIfNodeExists(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Watch the specified znode, but only if exists.
- setWebuiPort(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo.Builder
-
optional uint32 webui_port = 2;
- setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.HTable
-
Sets the size of the buffer in bytes.
- setWriteBufferSize(long) - Method in interface org.apache.hadoop.hbase.client.HTableInterface
-
- setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- setWriteBufferSize(long) - Method in interface org.apache.hadoop.hbase.client.Table
-
- setWriteBufferSize(long) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- setWriteFlushWalMarker(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionRequest.Builder
-
optional bool write_flush_wal_marker = 3;
- setWriteNum(QuotaProtos.TimedQuota) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_num = 3;
- setWriteNum(QuotaProtos.TimedQuota.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_num = 3;
- setWriterClsName(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional string writer_cls_name = 4;
- setWriterClsNameBytes(ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALHeader.Builder
-
optional string writer_cls_name = 4;
- setWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
optional uint64 write_requests_count = 9;
- setWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
- setWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region.Builder
-
optional int64 writeRequestsCount = 8;
- setWriteSize(QuotaProtos.TimedQuota) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_size = 4;
- setWriteSize(QuotaProtos.TimedQuota.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.Throttle.Builder
-
optional .TimedQuota write_size = 4;
- setWriteTime(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
required uint64 write_time = 4;
- setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Append
-
Deprecated.
- setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Delete
-
Deprecated.
- setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Increment
-
Deprecated.
- setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Mutation
-
- setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.client.Put
-
Deprecated.
- setWriteToWAL(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setWriteToWALIsSet(boolean) - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- setWroteFlushWalMarker(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.FlushRegionResponse.Builder
-
optional bool wrote_flush_wal_marker = 3;
- setYetToUpdateRegions(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetSchemaAlterStatusResponse.Builder
-
optional uint32 yet_to_update_regions = 1;
- setZnodeVersion(int) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination.ZkRegionMergeDetails
-
- setZnodeVersion(int) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination.ZkSplitTransactionDetails
-
- SEVENTY_FIFTH_PERCENTILE_METRIC_NAME - Static variable in interface org.apache.hadoop.metrics2.MetricHistogram
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.KeyValue
-
Creates a shallow copy of this KeyValue, reusing the data byte buffer.
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- shallowCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Create a new ByteRange
that points at this range's byte[].
- shallowCopy() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- shallowCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- shallowCopySubRange(int, int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Create a new ByteRange
that points at this range's byte[].
- shallowCopySubRange(int, int) - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- shallowCopySubRange(int, int) - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- SHARE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- shipBatch(long, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
-
Convience method to apply changes to metrics do to shipping a batch of logs.
- shipEdits(boolean, List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Do the shipping logic
- shouldArchiveTable(String) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
Determine if the given table should or should not allow its hfiles to be deleted in the archive
- shouldBeOnMaster(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Check if a region belongs to some small system table.
- shouldBypass() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
For use by the coprocessor framework.
- shouldCacheBlockOnRead(BlockType.BlockCategory) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Should we cache a block of a particular category? We always cache
important blocks such as index blocks, as long as the block cache is
available.
- shouldCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCacheBloomsOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCacheCompressed(BlockType.BlockCategory) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCacheDataCompressed() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCacheDataInL1() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCacheDataOnRead() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Returns whether the DATA blocks of this HFile should be cached on read or not (we always
cache the meta blocks, the INDEX and BLOOM blocks).
- shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCacheDataOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldCacheIndexesOnWrite() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldCloseConnection - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
-
- shouldComplete() - Method in class org.apache.hadoop.hbase.coprocessor.ObserverContext
-
For use by the coprocessor framework.
- shouldCompressTags() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldEvictBlocksOnClose() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldEvictOnClose() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldFixVersionFile() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- shouldIgnorePreCheckPermission() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- shouldIncludeMemstoreTS() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- shouldKillBeforeStoreUpdate() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.Testing
-
- shouldLockOnCacheMiss(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
If we make sure the block could not be cached, we will not acquire the lock
otherwise we will acquire lock
- shouldPrefetchBlocksOnOpen() - Method in class org.apache.hadoop.hbase.HColumnDescriptor
-
- shouldPrefetchOnOpen() - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- shouldReadBlockFromCache(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Return true if we may find this type of block in block cache.
- shouldReplayRecoveredEdits(HRegion) - Static method in class org.apache.hadoop.hbase.util.ServerRegionReplicaUtil
-
Returns whether to replay the recovered edits to flush the results.
- shouldRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
- shouldSeek(Scan, long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Check if this memstore may contain the required keys
- shouldSidelineBigOverlaps() - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.ConstantSizeRegionSplitPolicy
-
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
-
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
-
- shouldSplit() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- shouldSplitWal - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- shouldUseHBaseChecksum() - Method in class org.apache.hadoop.hbase.io.FSDataInputStreamWrapper
-
- shouldUseScanner(Scan, SortedSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore.MemStoreScanner
-
- shouldUseScanner(Scan, SortedSet<byte[]>, long) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
-
Allows to filter out scanners (both StoreFile and memstore) that we don't
want to use based on criteria such as Bloom filters and timestamp ranges.
- shouldUseScanner(Scan, SortedSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- shouldUseScanner(Scan, SortedSet<byte[]>, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- shouldUseThisHostnameInstead() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- shouldWriteBlock(boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Whether there is an inline block ready to be written.
- shouldWriteBlock(boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.InlineBlockWriter
-
Determines whether there is a new block to be written out.
- shouldWriteBlock(boolean) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- SHUFFLE_MAPS - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Specify if we have to shuffle the map tasks.
- shutdown() - Method in class org.apache.hadoop.hbase.ChoreService
-
shutdown the service.
- shutdown() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Shuts down the HBase cluster
- shutdown() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Shuts down the HBase cluster
- shutdown() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Clean up the environment
- shutdown(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- shutdown() - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- shutdown() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Shutdown the cache.
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
No operation for the shutdown in the memory IO engine
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
Close the file
- shutdown() - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
-
Shutdown the IOEngine
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- shutdown() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Shut down the mini HBase cluster
- shutdown() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Shutdown the threadpool executor service
- shutdown() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- shutdown(RpcController, MasterProtos.ShutdownRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- shutdown(RpcController, MasterProtos.ShutdownRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- shutdown(RpcController, MasterProtos.ShutdownRequest, RpcCallback<MasterProtos.ShutdownResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc Shutdown(.ShutdownRequest) returns (.ShutdownResponse);
- shutdown(RpcController, MasterProtos.ShutdownRequest, RpcCallback<MasterProtos.ShutdownResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc Shutdown(.ShutdownRequest) returns (.ShutdownResponse);
- shutdown(RpcController, MasterProtos.ShutdownRequest, RpcCallback<MasterProtos.ShutdownResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- shutdown() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- shutdown() - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Shut down the client.
- shutdown() - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
-
- shutdown() - Method in class org.apache.hadoop.hbase.util.ConnectionCache
-
Called when cache is no longer needed so that it can perform cleanup operations
- shutdown(List<JVMClusterUtil.MasterThread>, List<JVMClusterUtil.RegionServerThread>) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
- shutdown() - Method in class org.apache.hadoop.hbase.util.MetaUtils
-
Closes catalog regions if open.
- shutdown(Thread) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Shutdown passed thread using isAlive and join.
- shutdown(Thread, long) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Shutdown passed thread using isAlive and join.
- shutdown() - Method in class org.apache.hadoop.hbase.wal.BoundedRegionGroupingProvider
-
- shutdown() - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- shutdown() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Stop accepting new writes.
- shutdown() - Method in class org.apache.hadoop.hbase.wal.WALFactory
-
Tell the underlying WAL providers to shut down, but do not clean up underlying storage.
- shutdown() - Method in interface org.apache.hadoop.hbase.wal.WALProvider
-
persist outstanding WALs to storage and stop accepting new appends.
- shutdown() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- shutdownCluster() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- ShutdownHook - Class in org.apache.hadoop.hbase.regionserver
-
Manage regionserver shutdown hooks.
- ShutdownHook() - Constructor for class org.apache.hadoop.hbase.regionserver.ShutdownHook
-
- ShutdownHookManager - Class in org.apache.hadoop.hbase.util
-
This class provides ShutdownHookManager shims for HBase to interact with the Hadoop 1.0.x and the
Hadoop 2.0+ series.
- ShutdownHookManager() - Constructor for class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- signalAll() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- signalAll() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
-
In case the class is blocking on poll() waiting for items to be added,
this method should awake poll() and poll() should return.
- signalAll() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
-
- signalAll() - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
-
- SIGNATURE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription
-
- SimpleByteRange - Class in org.apache.hadoop.hbase.util
-
- SimpleByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
- SimpleByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
- SimpleByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
Create a new ByteRange
over the provided bytes
.
- SimpleByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimpleByteRange
-
Create a new ByteRange
over the provided bytes
.
- SimpleLoadBalancer - Class in org.apache.hadoop.hbase.master.balancer
-
Makes decisions about the placement and movement of Regions across
RegionServers.
- SimpleLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
-
- SimpleMutableByteRange - Class in org.apache.hadoop.hbase.util
-
- SimpleMutableByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
Create a new ByteRange
lacking a backing array and with an
undefined viewport.
- SimpleMutableByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
Create a new ByteRange
over a new backing array of size
capacity
.
- SimpleMutableByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
Create a new ByteRange
over the provided bytes
.
- SimpleMutableByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
Create a new ByteRange
over the provided bytes
.
- SimplePositionedByteRange - Class in org.apache.hadoop.hbase.util
-
- SimplePositionedByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new PositionedByteRange
lacking a backing array and with
an undefined viewport.
- SimplePositionedByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new PositionedByteRange
over a new backing array of
size capacity
.
- SimplePositionedByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new PositionedByteRange
over the provided bytes
.
- SimplePositionedByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
Create a new PositionedByteRange
over the provided bytes
.
- SimplePositionedMutableByteRange - Class in org.apache.hadoop.hbase.util
-
- SimplePositionedMutableByteRange() - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Create a new PositionedByteRange
lacking a backing array and with
an undefined viewport.
- SimplePositionedMutableByteRange(int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Create a new PositionedByteRange
over a new backing array of size
capacity
.
- SimplePositionedMutableByteRange(byte[]) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Create a new PositionedByteRange
over the provided bytes
.
- SimplePositionedMutableByteRange(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
Create a new PositionedByteRange
over the provided bytes
.
- SimpleRpcScheduler - Class in org.apache.hadoop.hbase.ipc
-
A scheduler that maintains isolated handler pools for general,
high-priority, and replication requests.
- SimpleRpcScheduler(Configuration, int, int, int, PriorityFunction, Abortable, int) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- SimpleRpcScheduler(Configuration, int, int, int, PriorityFunction, int) - Constructor for class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- SimpleRpcSchedulerFactory - Class in org.apache.hadoop.hbase.regionserver
-
- SimpleRpcSchedulerFactory() - Constructor for class org.apache.hadoop.hbase.regionserver.SimpleRpcSchedulerFactory
-
- SimpleScanLabelGenerator - Class in org.apache.hadoop.hbase.security.visibility
-
This is a simple implementation for ScanLabelGenerator.
- SimpleScanLabelGenerator() - Constructor for class org.apache.hadoop.hbase.security.visibility.SimpleScanLabelGenerator
-
- SimpleTotalOrderPartitioner<VALUE> - Class in org.apache.hadoop.hbase.mapreduce
-
A partitioner that takes start and end keys and uses bigdecimal to figure
which reduce a key belongs to.
- SimpleTotalOrderPartitioner() - Constructor for class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
- SINGLE_COLUMN_VALUE_FILTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.SingleColumnValueExcludeFilter
-
- SINGLE_QUOTE - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for a single quote
- SingleColumnValueExcludeFilter - Class in org.apache.hadoop.hbase.filter
-
A
Filter
that checks a single column value, but does not emit the
tested column.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueExcludeFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
-
Constructor for protobuf deserialization only.
- SingleColumnValueFilter - Class in org.apache.hadoop.hbase.filter
-
This filter is used to filter cells based on value.
- SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, byte[]) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for binary compare of the value of a single column.
- SingleColumnValueFilter(byte[], byte[], CompareFilter.CompareOp, ByteArrayComparable, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
-
Constructor for protobuf deserialization only.
- SingletonCoprocessorService - Interface in org.apache.hadoop.hbase.coprocessor
-
- sink - Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- SINK_AGE_OF_LAST_APPLIED_OP - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- SINK_APPLIED_BATCHES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- SINK_APPLIED_OPS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
-
- sinkToString() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
sinkToString
- size() - Method in class org.apache.hadoop.hbase.client.MultiAction
-
Get the total number of Actions
- size() - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- size() - Method in class org.apache.hadoop.hbase.client.Mutation
-
Number of KeyValues carried by this Mutation.
- size() - Method in class org.apache.hadoop.hbase.client.Result
-
- size() - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
- size() - Method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
-
- size() - Method in interface org.apache.hadoop.hbase.io.hfile.BlockCache
-
Returns the total size of the block cache, in bytes.
- size() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.CombinedBlockCache
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
-
- size() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
-
- size - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- size() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
- size() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- size() - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
-
Returns the number of elements in this collection.
- size() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
-
- size() - Method in class org.apache.hadoop.hbase.procedure2.util.ByteSlot
-
- size() - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
-
- size() - Method in class org.apache.hadoop.hbase.RegionLocations
-
Returns the size of the list even if some of the elements
might be null.
- size() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
-
Gets the size (number of entries) of the map.
- size() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
-
- size() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- size() - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- size() - Method in class org.apache.hadoop.hbase.util.BoundedArrayQueue
-
- size() - Method in class org.apache.hadoop.hbase.util.BoundedConcurrentLinkedQueue
-
- size() - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- size() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
-
- size - Variable in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- size() - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- size() - Method in interface org.apache.hadoop.hbase.util.PoolMap.Pool
-
- size() - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- size(K) - Method in class org.apache.hadoop.hbase.util.PoolMap
-
- size() - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- SIZE_TO_SPLIT_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The size the stripe should achieve to be considered for splitting into multiple stripes.
- SIZE_VALUE_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionSource
-
- SizedCellScanner - Interface in org.apache.hadoop.hbase.io
-
A CellScanner that knows its size in memory in bytes.
- sizeIndex() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- sizeIndexOfAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- SIZEOF_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of boolean in bytes
- SIZEOF_BYTE - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of byte in bytes
- SIZEOF_CHAR - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of char in bytes
- SIZEOF_DOUBLE - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of double in bytes
- SIZEOF_FLOAT - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of float in bytes
- SIZEOF_INT - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of int in bytes
- SIZEOF_LONG - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of long in bytes
- SIZEOF_SHORT - Static variable in class org.apache.hadoop.hbase.util.Bytes
-
Size of short in bytes
- sizeOfAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
- SIZEOFLOGQUEUE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- sizeToString(long) - Static method in class org.apache.hadoop.hbase.quotas.QuotaSettings
-
- skip(long) - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
-
Skips n
bytes of input from this input stream.
- skip(long) - Method in class org.apache.hadoop.hbase.io.LimitInputStream
-
- skip(PositionedByteRange) - Method in interface org.apache.hadoop.hbase.types.DataType
-
Skip src
's position forward over one encoded value.
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBytesBase
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.PBCell
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawByte
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawLong
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawShort
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawString
-
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
-
- skip() - Method in class org.apache.hadoop.hbase.types.StructIterator
-
Bypass the next encoded value.
- skip(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
Skip src
's position forward over one encoded value.
- skip(ByteBuffer, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Increment position in buffer.
- skip(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Skip buff
's position forward over one encoded value.
- SKIP_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
SKIP Array
- SKIP_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- SKIP_LINES_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- SKIP_TABLE_STATE_CHECK_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableStateData
-
- SKIP_TABLE_STATE_CHECK_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.EnableTableStateData
-
- SKIP_WAL_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Durability
-
SKIP_WAL = 1;
- SkipFilter - Class in org.apache.hadoop.hbase.filter
-
A wrapper filter that filters an entire row if any of the Cell checks do
not pass.
- SkipFilter(Filter) - Constructor for class org.apache.hadoop.hbase.filter.SkipFilter
-
- SKIPFLUSH_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
SKIPFLUSH = 2;
- skipKVsNewerThanReadpoint() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- skippedEdits - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- skipSleepCycle() - Method in class org.apache.hadoop.hbase.util.Sleeper
-
If currently asleep, stops sleeping; if not asleep, will skip the next
sleep cycle.
- skipStoreFileRangeCheck() - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- skipStoreFileRangeCheck(String) - Method in class org.apache.hadoop.hbase.regionserver.RegionSplitPolicy
-
- sleep(long, int) - Method in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
-
- sleep(long, int) - Method in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- sleep(long, int) - Method in class org.apache.hadoop.hbase.client.RegionServerCallable
-
- sleep(long, int) - Method in interface org.apache.hadoop.hbase.client.RetryingCallable
-
- sleep() - Method in class org.apache.hadoop.hbase.util.Sleeper
-
Sleep for period.
- sleep(long) - Method in class org.apache.hadoop.hbase.util.Sleeper
-
Sleep for period adjusted by passed startTime
- sleep(long) - Static method in class org.apache.hadoop.hbase.util.Threads
-
If interrupted, just prints out the interrupt on STDOUT, resets interrupt and returns
- sleeper - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- Sleeper - Class in org.apache.hadoop.hbase.util
-
Sleeper for current thread.
- Sleeper(int, Stoppable) - Constructor for class org.apache.hadoop.hbase.util.Sleeper
-
- sleepForRetries(String, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
Do the sleeping logic
- sleepForRetries(String, int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
Do the sleeping logic
- sleepUntilNextRetry() - Method in class org.apache.hadoop.hbase.util.RetryCounter
-
Sleep for a back off time as supplied by the backoff policy, and increases the attempts
- sleepWithoutInterrupt(long) - Static method in class org.apache.hadoop.hbase.util.Threads
-
Sleeps for the given amount of time even if interrupted.
- slop - Variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- SLOW_APPEND_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SLOW_APPEND_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SLOW_APPEND_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_APPEND_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_DELETE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_GET_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_GET_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_INCREMENT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_MUTATE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_MUTATE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SLOW_RESPONSE_NANO_SEC - Static variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- SLOW_THRIFT_CALL_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
-
- SMALL_COMPACTION_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SMALL_COMPACTION_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- SMALL_COMPACTION_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- SMALL_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- snapshot(String, TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Take a snapshot for the given table.
- snapshot(byte[], TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
public void snapshot(final String snapshotName, Create a timestamp consistent snapshot for the
given table.
- snapshot(String, TableName, HBaseProtos.SnapshotDescription.Type) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Create typed snapshot of the table.
- snapshot(HBaseProtos.SnapshotDescription) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Take a snapshot and wait for the server to complete that snapshot (blocking).
- snapshot(String, TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Take a snapshot for the given table.
- snapshot(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(byte[], byte[], HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create snapshot for the given table of given flush type.
- snapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
public void snapshot(final String snapshotName,
Create a timestamp consistent snapshot for the given table.
- snapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(String, TableName, HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Create typed snapshot of the table.
- snapshot(String, String, HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(String, byte[], HBaseProtos.SnapshotDescription.Type) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- snapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Take a snapshot and wait for the server to complete that snapshot (blocking).
- snapshot(RpcController, MasterProtos.SnapshotRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Triggers an asynchronous attempt to take a snapshot.
- snapshot - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- snapshot(RpcController, MasterProtos.SnapshotRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- snapshot(RpcController, MasterProtos.SnapshotRequest, RpcCallback<MasterProtos.SnapshotResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc Snapshot(.SnapshotRequest) returns (.SnapshotResponse);
- snapshot(RpcController, MasterProtos.SnapshotRequest, RpcCallback<MasterProtos.SnapshotResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc Snapshot(.SnapshotRequest) returns (.SnapshotResponse);
- snapshot(RpcController, MasterProtos.SnapshotRequest, RpcCallback<MasterProtos.SnapshotResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- snapshot() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Creates a snapshot of the current memstore.
- snapshot() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Creates a snapshot of the current memstore.
- snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Sample all the mutable metrics and put the snapshot in the builder
- snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MetricMutableQuantiles
-
- snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableHistogram
-
- snapshot(MetricsRecordBuilder, boolean) - Method in class org.apache.hadoop.metrics2.lib.MutableRangeHistogram
-
- snapshot() - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
-
Get a snapshot of the current values of all the tracked quantiles.
- SNAPSHOT_CLONE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
- SNAPSHOT_CLONE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
- SNAPSHOT_DIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Name of the directory to store all snapshots.
- SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.DeleteSnapshotRequest
-
- SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneRequest
-
- SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneRequest
-
- SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.RestoreSnapshotRequest
-
- SNAPSHOT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SnapshotRequest
-
- SNAPSHOT_IN_PROGRESS - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
This tag will be created in in-progess snapshots
- snapshot_jsp - Class in org.apache.hadoop.hbase.generated.master
-
- snapshot_jsp() - Constructor for class org.apache.hadoop.hbase.generated.master.snapshot_jsp
-
- SNAPSHOT_LAYOUT_VERSION - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Version of the fs layout for a snapshot.
- SNAPSHOT_MANIFEST_PREFIX - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2
-
- SNAPSHOT_MANIFEST_SIZE_LIMIT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
- SNAPSHOT_REQUEST_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
# of threads for snapshotting regions on the rs.
- SNAPSHOT_REQUEST_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Conf key for number of request threads to start snapshots on regionservers
- SNAPSHOT_REQUEST_WAKE_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Conf key for millis between checks to see if snapshot completed or if there are errors
- SNAPSHOT_RESTORE_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
- SNAPSHOT_RESTORE_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
- SNAPSHOT_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
- SNAPSHOT_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsSnapshotSource
-
- SNAPSHOT_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Keep threads alive in request pool for max of 300 seconds
- SNAPSHOT_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- SNAPSHOT_TIMEOUT_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Conf key for max time to keep threads in snapshot request pool waiting
- SNAPSHOT_TIMEOUT_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
- SNAPSHOT_TMP_DIR_NAME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
Temporary directory under the snapshot directory to store in-progress snapshots
- SnapshotCreationException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot could not be created due to a server-side error when
taking the snapshot.
- SnapshotCreationException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Used internally by the RPC engine to pass the exception back to the client.
- SnapshotCreationException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Failure to create the specified snapshot
- SnapshotCreationException(String, Throwable, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotCreationException
-
Failure to create the specified snapshot due to an external cause
- SnapshotDescriptionUtils - Class in org.apache.hadoop.hbase.snapshot
-
- SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter - Class in org.apache.hadoop.hbase.snapshot
-
Filter that only accepts completed snapshot directories
- SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter
-
- snapshotDisabledRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Take a snapshot of the specified disabled region
- SnapshotDoesNotExistException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when the server is looking for a snapshot but can't find the snapshot on the filesystem
- SnapshotDoesNotExistException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
-
- SnapshotDoesNotExistException(HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotDoesNotExistException
-
- SnapshotExistsException - Exception in org.apache.hadoop.hbase.snapshot
-
Thrown when a snapshot exists but should not
- SnapshotExistsException(String) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
-
- SnapshotExistsException(String, HBaseProtos.SnapshotDescription) - Constructor for exception org.apache.hadoop.hbase.snapshot.SnapshotExistsException
-
Failure due to the snapshot already existing
- SnapshotFileCache - Class in org.apache.hadoop.hbase.master.snapshot
-
Intelligently keep track of all the files for all the snapshots.
- SnapshotFileCache(Configuration, long, String, SnapshotFileCache.SnapshotFileInspector) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
Create a snapshot file cache for all snapshots under the specified [root]/.snapshot on the
filesystem.
- SnapshotFileCache(FileSystem, Path, long, long, String, SnapshotFileCache.SnapshotFileInspector) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
Create a snapshot file cache for all snapshots under the specified [root]/.snapshot on the
filesystem
- SnapshotFileCache.RefreshCacheTask - Class in org.apache.hadoop.hbase.master.snapshot
-
Simple helper task that just periodically attempts to refresh the cache
- SnapshotFileCache.RefreshCacheTask() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache.RefreshCacheTask
-
- SnapshotHFileCleaner - Class in org.apache.hadoop.hbase.master.snapshot
-
Implementation of a file cleaner that checks if a hfile is still used by snapshots of HBase
tables.
- SnapshotHFileCleaner() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- SnapshotInfo - Class in org.apache.hadoop.hbase.snapshot
-
Tool for dumping snapshot information.
- SnapshotInfo() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotInfo
-
- SnapshotInfo.SnapshotStats - Class in org.apache.hadoop.hbase.snapshot
-
Statistics about the snapshot
How many store files and logs are in the archive
How many store files and logs are shared with the table
Total store files and logs size and shared amount
- SNAPSHOTINFO_FILE - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
The file contains the snapshot basic information and it is under the directory of a snapshot.
- SnapshotLogCleaner - Class in org.apache.hadoop.hbase.master.snapshot
-
Implementation of a log cleaner that checks if a log is still used by
snapshots of HBase tables.
- SnapshotLogCleaner() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
- SnapshotManager - Class in org.apache.hadoop.hbase.master.snapshot
-
This class manages the procedure of taking and restoring snapshots.
- SnapshotManager() - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- SnapshotManager(MasterServices, MetricsMaster, ProcedureCoordinator, ExecutorService) - Constructor for class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Fully specify all necessary components of a snapshot manager.
- snapshotManifest - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- SnapshotManifest - Class in org.apache.hadoop.hbase.snapshot
-
Utility class to help read/write the Snapshot Manifest.
- SnapshotManifestV1 - Class in org.apache.hadoop.hbase.snapshot
-
DO NOT USE DIRECTLY.
- SnapshotManifestV2 - Class in org.apache.hadoop.hbase.snapshot
-
DO NOT USE DIRECTLY.
- SnapshotManifestV2() - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2
-
- SnapshotOfRegionAssignmentFromMeta - Class in org.apache.hadoop.hbase.master
-
Used internally for reading meta and constructing datastructures that are
then queried, for things like regions to regionservers, table to regions, etc.
- SnapshotOfRegionAssignmentFromMeta(Connection) - Constructor for class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- SnapshotOfRegionAssignmentFromMeta(Connection, Set<TableName>, boolean) - Constructor for class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
-
- SnapshotProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- SnapshotProtos.SnapshotDataManifest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SnapshotDataManifest
- SnapshotProtos.SnapshotDataManifest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SnapshotDataManifest
- SnapshotProtos.SnapshotDataManifestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SnapshotProtos.SnapshotFileInfo - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SnapshotFileInfo
- SnapshotProtos.SnapshotFileInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SnapshotFileInfo
- SnapshotProtos.SnapshotFileInfo.Type - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum SnapshotFileInfo.Type
- SnapshotProtos.SnapshotFileInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SnapshotProtos.SnapshotRegionManifest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SnapshotRegionManifest
- SnapshotProtos.SnapshotRegionManifest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SnapshotRegionManifest
- SnapshotProtos.SnapshotRegionManifest.FamilyFiles - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SnapshotRegionManifest.FamilyFiles
- SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SnapshotRegionManifest.FamilyFiles
- SnapshotProtos.SnapshotRegionManifest.FamilyFilesOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SnapshotProtos.SnapshotRegionManifest.StoreFile - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SnapshotRegionManifest.StoreFile
- SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SnapshotRegionManifest.StoreFile
- SnapshotProtos.SnapshotRegionManifest.StoreFileOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SnapshotProtos.SnapshotRegionManifestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- SnapshotReferenceUtil - Class in org.apache.hadoop.hbase.snapshot
-
Utility methods for interacting with the snapshot referenced files.
- SnapshotReferenceUtil.SnapshotVisitor - Interface in org.apache.hadoop.hbase.snapshot
-
- SnapshotReferenceUtil.StoreFileVisitor - Interface in org.apache.hadoop.hbase.snapshot
-
- snapshotRegions(List<Pair<HRegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.DisabledTableSnapshotHandler
-
- snapshotRegions(List<Pair<HRegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.EnabledTableSnapshotHandler
-
This method kicks off a snapshot procedure.
- snapshotRegions(List<Pair<HRegionInfo, ServerName>>) - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
Snapshot the specified regions
- SNAPSHOTS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse
-
- SnapshotSentinel - Interface in org.apache.hadoop.hbase.master
-
Watch the current snapshot under process
- snapshotTable - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- sniff(Admin, TableName) - Static method in class org.apache.hadoop.hbase.tool.Canary
-
Canary entry point for specified table.
- socket - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl.Connection
-
- socket - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- SOCKET_RETRY_WAIT_MS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The delay when re-trying a socket operation in a loop (HBASE-4712)
- SOCKET_TIMEOUT_CONNECT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- SOCKET_TIMEOUT_READ - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
How long we wait when we wait for an answer.
- SOCKET_TIMEOUT_WRITE - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- socketFactory - Variable in class org.apache.hadoop.hbase.ipc.RpcClientImpl
-
- socketSendBufferSize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- SOFT_LIMIT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.TimedQuota
-
- solve() - Method in class org.apache.hadoop.hbase.util.MunkresAssignment
-
Get the optimal assignments.
- sortAndMerge(List<MultiRowRangeFilter.RowRange>) - Static method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
-
sort the ranges and if the ranges with overlap, then merge them.
- sortColumns - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- SORTED_ORDINAL_SERIALIZATION_FORMAT - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
Visibility serialization version format.
- SORTED_ORDINAL_SERIALIZATION_FORMAT_TAG - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- SORTED_ORDINAL_SERIALIZATION_FORMAT_TAG_VAL - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
Byte representation of the visibility_serialization_version
- SORTED_PREFIXES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter
-
- sortedColumns - Variable in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- SortedCopyOnWriteSet<E> - Class in org.apache.hadoop.hbase.util
-
Simple
SortedSet
implementation that uses an internal
TreeSet
to provide ordering.
- SortedCopyOnWriteSet() - Constructor for class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- SortedCopyOnWriteSet(Collection<? extends E>) - Constructor for class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- SortedCopyOnWriteSet(Comparator<? super E>) - Constructor for class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- sortedIndexByInsertionId - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
-
- sortedIndexByUniqueIndex - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
-
- sortedPrefixes - Variable in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- sortedRanges - Variable in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
-
- sortedUniqueValues - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
- SOURCE_AGE_OF_LAST_SHIPPED_OP - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_CLOSED_LOGS_WITH_UNKNOWN_LENGTH - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_COMPLETED_LOGS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_COMPLETED_RECOVERY_QUEUES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.ForeignExceptionMessage
-
- SOURCE_LOG_EDITS_FILTERED - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_LOG_READ_IN_BYTES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_LOG_READ_IN_EDITS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_REPEATED_LOG_FILE_BYTES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_RESTARTED_LOG_READING - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_SHIPPED_BATCHES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_SHIPPED_KBS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_SHIPPED_OPS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_SIZE_OF_LOG_QUEUE - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_UNCLEANLY_CLOSED_IGNORED_IN_BYTES - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- SOURCE_UNCLEANLY_CLOSED_LOGS - Static variable in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- sourceScanner - Variable in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
Source scanner that is tracking KV count; may be null if source is not StoreScanner
- sourceToString() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationLoad
-
sourceToString
- SPAN_RECEIVERS_CONF_KEY - Static variable in class org.apache.hadoop.hbase.trace.SpanReceiverHost
-
- SpanReceiverHost - Class in org.apache.hadoop.hbase.trace
-
This class provides functions for reading the names of SpanReceivers from
hbase-site.xml, adding those SpanReceivers to the Tracer, and closing those
SpanReceivers when appropriate.
- SPEC_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionInTransition
-
- SPECIFIC_WRITE_THREAD - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- split(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Split a table.
- split(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Split a table.
- split(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Split a table.
- split(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- split(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- split(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Split a table.
- split(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- split(ServerName, HRegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- split(int, ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
Called when we need to convert a leaf node into a branch with 2 leaves.
- split(RpcController, AdminProtos.AdminService.BlockingInterface, HRegionInfo, byte[]) - Static method in class org.apache.hadoop.hbase.protobuf.ProtobufUtil
-
A helper to split a region using admin protocol.
- split(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Split passed range.
- split(byte[], byte[], boolean, int) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Split passed range.
- split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- split(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Split a pre-existing region into 2 regions.
- split(int) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
Split an entire table.
- split(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- split(int) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- split(Path, Path, Path, FileSystem, Configuration, WALFactory) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
- split2(BigInteger, BigInteger) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
Divide 2 numbers in half (for split algorithm)
- SPLIT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- SPLIT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_KEYS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest
-
- SPLIT_LOGDIR_NAME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Used to construct the name of the splitlog directory for a region server
- SPLIT_PARTS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
The target count of new stripes to produce when splitting a stripe.
- SPLIT_POINT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.SplitRegionRequest
-
- SPLIT_POLICY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
- SPLIT_PONR_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode
-
SPLIT_PONR = 5;
- SPLIT_QUEUE_LENGTH - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_QUEUE_LENGTH_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_REQUEST_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_REQUEST_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_REVERTED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode
-
SPLIT_REVERTED = 9;
- SPLIT_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
- SPLIT_SIZE_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
- SPLIT_SKIP_ERRORS_DEFAULT - Static variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
By default we retry errors in splitting, rather than skipping.
- SPLIT_SUCCESS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_SUCCESS_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- SPLIT_THREADS - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- SPLIT_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- SPLIT_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
- SPLIT_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
-
- SPLIT_TRANSACTION_IMPL_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
-
- SPLIT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
-
SPLIT = 8;
- SPLIT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.TransitionCode
-
SPLIT = 7;
- SPLITA_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The lower-half split region column qualifier
- SPLITB_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The upper-half split region column qualifier
- splitCell - Variable in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- splitKerberosName(String) - Static method in class org.apache.hadoop.hbase.security.SaslUtil
-
Splitting fully qualified Kerberos name into parts
- splitkey - Variable in class org.apache.hadoop.hbase.io.HalfStoreFileReader
-
- SPLITKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FSProtos.Reference
-
- splitLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- splitLog(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- splitLog(Set<ServerName>, PathFilter) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
This method is the base split method that splits WAL files matching a filter.
- SplitLogCounters - Class in org.apache.hadoop.hbase
-
Counters kept by the distributed WAL split log process.
- SplitLogCounters() - Constructor for class org.apache.hadoop.hbase.SplitLogCounters
-
- splitLogDistributed(Path) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- splitLogDistributed(List<Path>) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
The caller will block until all the log files of the given region server have been processed -
successfully split or an error is encountered - by an available worker region server.
- splitLogDistributed(Set<ServerName>, List<Path>, PathFilter) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
The caller will block until all the hbase:meta log files of the given region server have been
processed - successfully split or an error is encountered - by an available worker region
server.
- splitLogFile(Path, FileStatus, FileSystem, Configuration, CancelableProgressable, LastSequenceId, CoordinatedStateManager, ZooKeeperProtos.SplitLogTask.RecoveryMode, WALFactory) - Static method in class org.apache.hadoop.hbase.wal.WALSplitter
-
Splits a WAL file into region's recovered-edits directory.
- SplitLogManager - Class in org.apache.hadoop.hbase.master
-
Distributes the task of log splitting to the available region servers.
- SplitLogManager(Server, Configuration, Stoppable, MasterServices, ServerName) - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager
-
Its OK to construct this object even when region-servers are not online.
- SplitLogManager.ResubmitDirective - Enum in org.apache.hadoop.hbase.master
-
- SplitLogManager.Task - Class in org.apache.hadoop.hbase.master
-
in memory state of an active task.
- SplitLogManager.Task() - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- SplitLogManager.TaskBatch - Class in org.apache.hadoop.hbase.master
-
Keeps track of the batch of tasks submitted together by a caller in splitLogDistributed().
- SplitLogManager.TaskBatch() - Constructor for class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
- SplitLogManager.TerminationStatus - Enum in org.apache.hadoop.hbase.master
-
- SplitLogManagerCoordination - Interface in org.apache.hadoop.hbase.coordination
-
Coordination for SplitLogManager.
- splitLogManagerCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- SplitLogManagerCoordination.SplitLogManagerDetails - Class in org.apache.hadoop.hbase.coordination
-
Detail class that shares data between coordination and split log manager
- SplitLogManagerCoordination.SplitLogManagerDetails(ConcurrentMap<String, SplitLogManager.Task>, MasterServices, Set<String>, ServerName) - Constructor for class org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination.SplitLogManagerDetails
-
- SplitLogTask - Class in org.apache.hadoop.hbase
-
State of a WAL log split during distributed splitting.
- SplitLogTask.Done - Class in org.apache.hadoop.hbase
-
- SplitLogTask.Done(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Done
-
- SplitLogTask.Err - Class in org.apache.hadoop.hbase
-
- SplitLogTask.Err(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Err
-
- SplitLogTask.Owned - Class in org.apache.hadoop.hbase
-
- SplitLogTask.Owned(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Owned
-
- SplitLogTask.Resigned - Class in org.apache.hadoop.hbase
-
- SplitLogTask.Resigned(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Resigned
-
- SplitLogTask.Unassigned - Class in org.apache.hadoop.hbase
-
- SplitLogTask.Unassigned(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Unassigned
-
- SplitLogWorker - Class in org.apache.hadoop.hbase.regionserver
-
This worker is spawned in every regionserver, including master.
- SplitLogWorker(Server, Configuration, RegionServerServices, SplitLogWorker.TaskExecutor) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
- SplitLogWorker(Server, Configuration, RegionServerServices, LastSequenceId, WALFactory) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
- SplitLogWorker.TaskExecutor - Interface in org.apache.hadoop.hbase.regionserver
-
Objects implementing this interface actually do the task that has been
acquired by a
SplitLogWorker
.
- SplitLogWorker.TaskExecutor.Status - Enum in org.apache.hadoop.hbase.regionserver
-
- SplitLogWorkerCoordination - Interface in org.apache.hadoop.hbase.coordination
-
- splitLogWorkerCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- SplitLogWorkerCoordination.SplitTaskDetails - Interface in org.apache.hadoop.hbase.coordination
-
Interface for log-split tasks Used to carry implementation details in encapsulated way through
Handlers to the coordination API.
- splitLogZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- splitMetaLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Specialized method to handle the splitting for meta WAL
- splitMetaLog(Set<ServerName>) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Specialized method to handle the splitting for meta WAL
- splitRegion(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Split an individual region.
- splitRegion(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Split an individual region.
- splitRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Split an individual region.
- splitRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Split an individual region.
- splitRegion(Connection, HRegionInfo, HRegionInfo, HRegionInfo, ServerName, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Splits the region into two in an atomic operation.
- splitRegion(RpcController, AdminProtos.SplitRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
-
- splitRegion(RpcController, AdminProtos.SplitRegionRequest, RpcCallback<AdminProtos.SplitRegionResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
-
rpc SplitRegion(.SplitRegionRequest) returns (.SplitRegionResponse);
- splitRegion(RpcController, AdminProtos.SplitRegionRequest, RpcCallback<AdminProtos.SplitRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
rpc SplitRegion(.SplitRegionRequest) returns (.SplitRegionResponse);
- splitRegion(RpcController, AdminProtos.SplitRegionRequest, RpcCallback<AdminProtos.SplitRegionResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
-
- splitRegion(RpcController, AdminProtos.SplitRegionRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Split a region on the region server.
- splits - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- splitStoreFile(LoadIncrementalHFiles.LoadQueueItem, Table, byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
- SPLITTING_EXT - Static variable in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
File Extension used while splitting an WAL into regions (HBASE-2312)
- SPLITTING_NEW_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
-
SPLITTING_NEW = 13;
- SPLITTING_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState.State
-
SPLITTING = 7;
- SplitTransaction - Interface in org.apache.hadoop.hbase.regionserver
-
Executes region split as a "transaction".
- SplitTransaction.JournalEntry - Interface in org.apache.hadoop.hbase.regionserver
-
Split transaction journal entry
- SplitTransaction.SplitTransactionPhase - Enum in org.apache.hadoop.hbase.regionserver
-
Each enum is a step in the split transaction.
- SplitTransaction.TransactionListener - Interface in org.apache.hadoop.hbase.regionserver
-
Split transaction listener
- SplitTransactionCoordination - Interface in org.apache.hadoop.hbase.coordination
-
Coordination operations for split transaction.
- splitTransactionCoordination - Variable in class org.apache.hadoop.hbase.coordination.ZkCoordinatedStateManager
-
- SplitTransactionCoordination.SplitTransactionDetails - Interface in org.apache.hadoop.hbase.coordination
-
Dummy interface for split transaction details.
- SplitTransactionFactory - Class in org.apache.hadoop.hbase.regionserver
-
A factory for creating SplitTransactions, which execute region split as a "transaction".
- SplitTransactionFactory(Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransactionFactory
-
- SplitTransactionImpl - Class in org.apache.hadoop.hbase.regionserver
-
- SplitTransactionImpl(Region, byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
Constructor
- SplitTransactionImpl.JournalEntryImpl - Class in org.apache.hadoop.hbase.regionserver
-
- SplitTransactionImpl.JournalEntryImpl(SplitTransaction.SplitTransactionPhase) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
-
- SplitTransactionImpl.JournalEntryImpl(SplitTransaction.SplitTransactionPhase, long) - Constructor for class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl.JournalEntryImpl
-
- SPNEGO_FILTER - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- src - Variable in class org.apache.hadoop.hbase.types.StructIterator
-
- SRC_CHECKSUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- srcChecksum - Static variable in class org.apache.hadoop.hbase.Version
-
- SslRMIClientSocketFactorySecure - Class in org.apache.hadoop.hbase
-
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
- SslRMIClientSocketFactorySecure() - Constructor for class org.apache.hadoop.hbase.SslRMIClientSocketFactorySecure
-
- SslRMIServerSocketFactorySecure - Class in org.apache.hadoop.hbase
-
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
- SslRMIServerSocketFactorySecure() - Constructor for class org.apache.hadoop.hbase.SslRMIServerSocketFactorySecure
-
- SslSelectChannelConnectorSecure - Class in org.apache.hadoop.hbase.jetty
-
Avoid SSL V3.0 "Poodle" Vulnerability - CVE-2014-3566
- SslSelectChannelConnectorSecure() - Constructor for class org.apache.hadoop.hbase.jetty.SslSelectChannelConnectorSecure
-
- SslSocketConnectorSecure - Class in org.apache.hadoop.hbase.http
-
This subclass of the Jetty SslSocketConnector exists solely to control
the TLS protocol versions allowed.
- SslSocketConnectorSecure() - Constructor for class org.apache.hadoop.hbase.http.SslSocketConnectorSecure
-
- STACK_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- STACK_TRACE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- STALE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- STALE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse
-
- STAMP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- stampSet - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- standardizeQuorumServerString(String, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Standardize the ZK quorum string: make it a "server:clientport" list, separated by ','
- standardSchemeReadValue(TProtocol, TField) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- standardSchemeWriteValue(TProtocol) - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- start() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Start monitoring for archive updates
- start(RootDoc) - Static method in class org.apache.hadoop.hbase.classification.tools.ExcludePrivateAnnotationsStandardDoclet
-
- start(RootDoc) - Static method in class org.apache.hadoop.hbase.classification.tools.IncludePublicAnnotationsStandardDoclet
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.constraint.ConstraintProcessor
-
- start() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
Starts service.
- start() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
Stores a reference to the coprocessor environment provided by the
RegionCoprocessorHost
from the region where this
coprocessor is loaded.
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
-
Stores a reference to the coprocessor environment provided by the
RegionCoprocessorHost
from the region where this
coprocessor is loaded.
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
-
Stores a reference to the coprocessor environment provided by the
RegionCoprocessorHost
from the region where this
coprocessor is loaded.
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
Stores a reference to the coprocessor environment provided by the
RegionCoprocessorHost
from the region where this
coprocessor is loaded.
- start(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
-
- start() - Method in class org.apache.hadoop.hbase.errorhandling.TimeoutExceptionInjector
-
Start a timer to fail a process if it takes longer than the expected time to complete.
- start() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Start the server.
- start() - Method in class org.apache.hadoop.hbase.http.InfoServer
-
- start() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- start(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- start() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Prepares for request serving.
- start() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Starts the service.
- start() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- start() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.JMXListener
-
- START - Static variable in class org.apache.hadoop.hbase.mapreduce.SimpleTotalOrderPartitioner
-
Deprecated.
- start() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
-
- start() - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- start() - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
Start accepting flush table requests.
- start(ProcedureCoordinator) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureCoordinatorRpcs
-
Initialize and start threads necessary to connect an implementation's rpc mechanisms.
- start(String, ProcedureMember) - Method in interface org.apache.hadoop.hbase.procedure.ProcedureMemberRpcs
-
Initialize and start any threads or connections the member needs.
- start() - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
-
Start accepting procedure requests.
- start() - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
-
- start(ProcedureCoordinator) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
Start monitoring znodes in ZK - subclass hook to start monitoring znodes they are about.
- start(String, ProcedureMember) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
- start(int) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- start(int) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
Start/Open the procedure store
- start(int) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- start() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- start() - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- start(RpcScheduler) - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
- start(String) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputController
-
Start a compaction.
- start(String) - Method in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- start(String) - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- start(ChoreService) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- start() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Start accepting snapshot requests.
- start() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
start the SplitLogWorker thread
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- start() - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
- start() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- start() - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- start(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController.VisibilityReplication
-
- start() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- start() - Method in class org.apache.hadoop.hbase.security.visibility.ZKVisibilityLabelWatcher
-
- start() - Method in class org.apache.hadoop.hbase.util.HasThread
-
- start() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- start() - Method in class org.apache.hadoop.hbase.ZKNamespaceManager
-
- start() - Method in class org.apache.hadoop.hbase.zookeeper.DrainingServerTracker
-
Starts the tracking of draining RegionServers.
- start() - Method in class org.apache.hadoop.hbase.zookeeper.RegionServerTracker
-
Starts the tracking of online RegionServers.
- start() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
- start() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Starts the tracking of the node in ZooKeeper.
- START_CODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ServerName
-
- START_DATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ClusterUp
-
- START_FLUSH_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.FlushAction
-
START_FLUSH = 0;
- START_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- START_KEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.RegionInfo
-
- START_ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- START_ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- START_ROW_INCLUSIVE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- START_TIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- START_TIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- START_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
Deprecated.
- START_TIME_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
-
- startAndPrefix - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
the prefix (and thus start row) of the keys you want
- startAndWait() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
-
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Starts encoding for a block of KeyValues.
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Starts encoding for a block of KeyValues.
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoderImpl
-
- startBlockEncoding(HFileBlockEncodingContext, DataOutputStream) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpDataBlockEncoder
-
- startCacheFlush(byte[], Set<byte[]>) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- startCacheFlush(byte[], Set<byte[]>) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
WAL keeps track of the sequence numbers that are as yet not flushed im memstores
in order to be able to do accounting to figure which WALs can be let go.
- startCancel() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcController
-
- startCancel() - Method in class org.apache.hadoop.hbase.ipc.TimeLimitedRpcController
-
- startcode - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
This servers startcode.
- STARTCODE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node
-
- STARTCODE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
The startcode column qualifier
- STARTCODE_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The startcode column qualifier
- startConnectorServer(int, int) - Method in class org.apache.hadoop.hbase.JMXListener
-
- startDelay(boolean) - Method in interface org.apache.hadoop.hbase.ipc.Delayable
-
Signal that the call response should be delayed, thus freeing the RPC
server to handle different requests.
- startDelay(boolean) - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Call
-
- startExecutorService(ExecutorType, int) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- startHandlers(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- startHandlers(String, int, List<BlockingQueue<CallRunner>>, int, int, int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- startHandlers(int) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- startKey - Variable in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- STARTKEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Region
-
- startOperation(long, long, Stoppable) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
-
Starts the operation if operation with such nonce has not already succeeded.
- startProcedure(ForeignExceptionDispatcher, String, byte[], List<String>) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Kick off the named procedure
Currently only one procedure with the same type and name is allowed to run at a time.
- startRegionMergeTransaction(HRegionInfo, ServerName, HRegionInfo, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coordination.RegionMergeCoordination
-
Start the region merge transaction
- startRegionMergeTransaction(HRegionInfo, ServerName, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.coordination.ZkRegionMergeCoordination
-
Creates a new ephemeral node in the PENDING_MERGE state for the merged region.
- startRegionOperation() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- startRegionOperation(Region.Operation) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- startRegionOperation() - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
This method needs to be called before any public call that reads or
modifies data.
- startRegionOperation(Region.Operation) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
This method needs to be called before any public call that reads or
modifies data.
- startReplicationService() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Start replication services.
- startReplicationService() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
If replication is enabled and this cluster is a master,
it starts
- startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Starting row in table to scan.
- startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Starting row in table to scan.
- startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Starting row in table to scan.
- startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Starting row in table to scan.
- startRow - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- startRow - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- STARTROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- startSplitTransaction(HRegion, ServerName, HRegionInfo, HRegionInfo) - Method in interface org.apache.hadoop.hbase.coordination.SplitTransactionCoordination
-
init coordination for split transaction
- startSplitTransaction(HRegion, ServerName, HRegionInfo, HRegionInfo) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitTransactionCoordination
-
Creates a new ephemeral node in the PENDING_SPLIT state for the specified region.
- startStateTracker(ZooKeeperWatcher, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
start a state tracker to check whether this peer is enabled or not
- startsWith(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
Return true if the byte array on the right is a prefix of the byte
array on the left.
- startTableCFsTracker(ZooKeeperWatcher, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
start a table-cfs tracker to listen the (table, cf-list) map change
- STARTTIME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner
-
- startup() - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost.Environment
-
Initialize the environment
- startup() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
Start the cluster.
- startup() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
-
- startup() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
-
Start the replication
- startup(List<JVMClusterUtil.MasterThread>, List<JVMClusterUtil.RegionServerThread>) - Static method in class org.apache.hadoop.hbase.util.JVMClusterUtil
-
Start the cluster.
- startup(File) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- startup(File, int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
- startWriterThreads() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
Called by the constructor to start the writer threads.
- startWriterThreads() - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
Start the threads that will pump data from the entryBuffers to the output files.
- startWriting(BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
-
Starts writing into the block.
- state - Variable in enum org.apache.hadoop.hbase.security.SaslStatus
-
- state() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- STATE_DATA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionState
-
- STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetProcedureResultResponse
-
- STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure
-
- STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData
-
- STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.MetaRegionServer
-
- STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState
-
- STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask
-
- STATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table
-
- STATE_QUALIFIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- STATE_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HConstants
-
The state column qualifier
- StateDumpServlet - Class in org.apache.hadoop.hbase.monitoring
-
- StateDumpServlet() - Constructor for class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- statelessUncompressor - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- StateMachineProcedure<TEnvironment,TState> - Class in org.apache.hadoop.hbase.procedure2
-
Procedure described by a series of steps.
- StateMachineProcedure() - Constructor for class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- StateMachineProcedure.Flow - Enum in org.apache.hadoop.hbase.procedure2
-
- STATIC_BLOOM_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STATIC_BLOOM_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STATIC_INDEX_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STATIC_INDEX_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- StaticUserWebFilter - Class in org.apache.hadoop.hbase.http.lib
-
Provides a servlet filter that pretends to authenticate a fake user (Dr.Who)
so that the web UI is usable for a secure cluster without authentication.
- StaticUserWebFilter() - Constructor for class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter
-
- StaticUserWebFilter.StaticUserFilter - Class in org.apache.hadoop.hbase.http.lib
-
- StaticUserWebFilter.StaticUserFilter() - Constructor for class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
-
- STATS_RECORD_SEP - Static variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Record separator for the Bloom filter statistics human-readable string
- StatsTrackingRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
-
An
RpcRetryingCaller
that will update the per-region stats for the call on return,
if stats are available
- StatsTrackingRpcRetryingCaller(long, int, int, ServerStatisticTracker) - Constructor for class org.apache.hadoop.hbase.client.StatsTrackingRpcRetryingCaller
-
- StatsTrackingRpcRetryingCaller(long, int, RetryingCallerInterceptor, int, ServerStatisticTracker) - Constructor for class org.apache.hadoop.hbase.client.StatsTrackingRpcRetryingCaller
-
- status - Variable in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
-
- status - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
-
- STATUS_MULTICAST_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
IP to use for the multicast status messages between the master and the clients.
- STATUS_MULTICAST_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
The address to use for binding the local socket for receiving multicast.
- STATUS_MULTICAST_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
The port to use for the multicast messages.
- STATUS_PUBLISH_PERIOD - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
The minimum time between two status messages, in milliseconds.
- STATUS_PUBLISHED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Setting to activate, or not, the publication of the status by the master.
- STATUS_PUBLISHED_DEFAULT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- STATUS_PUBLISHER_CLASS - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
The implementation class used to publish the status.
- std(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
This is the client side interface/handle for calling the std method for a
given cf-cq combination.
- std(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
This is the client side interface/handle for calling the std method for a
given cf-cq combination.
- std - Variable in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- stepDownAsLeader() - Method in class org.apache.hadoop.hbase.zookeeper.ZKLeaderManager
-
Deprecated.
Removes the leader znode, if it is currently claimed by this instance.
- STEPS_PER_REGION_KEY - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- stepsAfterPONR(Server, RegionServerServices, HRegion) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
Deprecated.
- stepsAfterPONR(Server, RegionServerServices, HRegion, User) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- stepsAfterPONR(Server, RegionServerServices, PairOfSameType<Region>) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
Deprecated.
- stepsAfterPONR(Server, RegionServerServices, PairOfSameType<Region>, User) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- stepsBeforePONR(Server, RegionServerServices, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- stepsBeforePONR(Server, RegionServerServices, boolean) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- StochasticLoadBalancer - Class in org.apache.hadoop.hbase.master.balancer
-
This is a best effort load balancer.
- StochasticLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- stop(String) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
-
- stop() - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
-
Stop this tracker and the passed zookeeper
- stop() - Method in interface org.apache.hadoop.hbase.CoordinatedStateManager
-
Stops service.
- stop() - Method in class org.apache.hadoop.hbase.coordination.BaseCoordinatedStateManager
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterAndRegionObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseMasterObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRegionServerObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.BaseWALObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.RowCountEndpoint
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.coprocessor.MultiRowMutationEndpoint
-
- stop(CoprocessorEnvironment) - Method in interface org.apache.hadoop.hbase.Coprocessor
-
- stop() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
stop the server
- stop() - Method in class org.apache.hadoop.hbase.http.InfoServer
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Stops serving new requests.
- stop() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Stops the service.
- stop() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
- stop() - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.JMXListener
-
- stop() - Method in class org.apache.hadoop.hbase.master.ActiveMasterManager
-
- stop() - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
-
- stop() - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- stop() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Stop the ServerManager.
- stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotLogCleaner
-
- stop(String) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
- stop() - Method in class org.apache.hadoop.hbase.master.SplitLogManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.procedure.flush.MasterFlushTableProcedureManager
-
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager
-
Close this and all running tasks
- stop(String) - Method in class org.apache.hadoop.hbase.procedure.MasterProcedureManagerHost
-
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManager
-
Close this and all running procedure tasks
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure.RegionServerProcedureManagerHost
-
- stop() - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
- stop(boolean) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
Stop/Close the procedure store
- stop(boolean) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- stop() - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.quotas.QuotaCache
-
- stop() - Method in class org.apache.hadoop.hbase.quotas.RegionServerQuotaManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.compactions.NoLimitCompactionThroughputController
-
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.compactions.PressureAwareCompactionThroughputController
-
- stop() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager
-
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionsCleaner
-
- stop(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- stop(boolean) - Method in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager
-
Close this and all running snapshot tasks
- stop() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
stop the SplitLogWorker thread
- stop(String) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- stop() - Static method in class org.apache.hadoop.hbase.rest.RESTServlet
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.AccessController
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint
-
- stop() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.token.TokenProvider
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
- stop(CoprocessorEnvironment) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController.VisibilityReplication
-
- stop() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- stop(String) - Method in interface org.apache.hadoop.hbase.Stoppable
-
Stop this service.
- stop() - Method in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- stop() - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
-
- stop() - Method in class org.apache.hadoop.hbase.util.JvmPauseMonitor
-
- stop() - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Stop working.
- stop() - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
- stop() - Method in class org.apache.hadoop.metrics2.lib.MetricsExecutorImpl
-
- stop() - Method in interface org.apache.hadoop.metrics2.MetricsExecutor
-
- STOP_ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- STOP_ROW_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- STOP_ROW_INCLUSIVE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.RowRange
-
- STOP_ROW_KEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.InclusiveStopFilter
-
- STOP_TIMEOUT_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Time to wait for server to stop gracefully
- stopAndDrainOps() - Method in class org.apache.hadoop.hbase.util.DrainBarrier
-
Blocks new operations from starting, waits for the current ones to drain.
- stopAndDrainOpsOnce() - Method in class org.apache.hadoop.hbase.util.DrainBarrier
-
Blocks new operations from starting, waits for the current ones to drain.
- stopAndWait() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
-
- stopConnectorServer() - Method in class org.apache.hadoop.hbase.JMXListener
-
- stopMaster() - Method in interface org.apache.hadoop.hbase.client.Admin
-
Shuts down the current HBase master only.
- stopMaster() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Shuts down the current HBase master only.
- stopMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- stopMaster(RpcController, MasterProtos.StopMasterRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- stopMaster(RpcController, MasterProtos.StopMasterRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- stopMaster(RpcController, MasterProtos.StopMasterRequest, RpcCallback<MasterProtos.StopMasterResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc StopMaster(.StopMasterRequest) returns (.StopMasterResponse);
- stopMaster(RpcController, MasterProtos.StopMasterRequest, RpcCallback<MasterProtos.StopMasterResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc StopMaster(.StopMasterRequest) returns (.StopMasterResponse);
- stopMaster(RpcController, MasterProtos.StopMasterRequest, RpcCallback<MasterProtos.StopMasterResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- Stoppable - Interface in org.apache.hadoop.hbase
-
Implementers are Stoppable.
- StoppedRpcClientException - Exception in org.apache.hadoop.hbase.ipc
-
- StoppedRpcClientException() - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
-
- StoppedRpcClientException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.StoppedRpcClientException
-
- stopProcessingTasks() - Method in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
called when Coordination should stop processing tasks and exit
- stopProcessingTasks() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
- stopRegionServer(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Stop the designated regionserver
- stopRegionServer(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Stop the designated regionserver
- stopReplicationService() - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
-
Stops replication service.
- stopReplicationService() - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
Stops replication service.
- stopReplicationSinkServices() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
-
stop the thread pool executor.
- stopRequested - Variable in class org.apache.hadoop.hbase.regionserver.Leases
-
- stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
row to stop scanning on.
- stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
row to stop scanning on.
- stopRow - Variable in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- stopRow - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- stopServer(RpcController, AdminProtos.StopServerRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
-
- stopServer(RpcController, AdminProtos.StopServerRequest, RpcCallback<AdminProtos.StopServerResponse>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
-
rpc StopServer(.StopServerRequest) returns (.StopServerResponse);
- stopServer(RpcController, AdminProtos.StopServerRequest, RpcCallback<AdminProtos.StopServerResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
rpc StopServer(.StopServerRequest) returns (.StopServerResponse);
- stopServer(RpcController, AdminProtos.StopServerRequest, RpcCallback<AdminProtos.StopServerResponse>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
-
- stopServer(RpcController, AdminProtos.StopServerRequest) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
-
Stop the region server.
- stopServiceThreads() - Method in class org.apache.hadoop.hbase.master.HMaster
-
- stopServiceThreads() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Wait on all threads to finish.
- stopTask() - Method in class org.apache.hadoop.hbase.regionserver.SplitLogWorker
-
If the worker is doing a task i.e.
- StorageClusterStatusMessage - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusMessage.StorageClusterStatus - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus
- StorageClusterStatusMessage.StorageClusterStatus.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus
- StorageClusterStatusMessage.StorageClusterStatus.Node - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node
- StorageClusterStatusMessage.StorageClusterStatus.Node.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node
- StorageClusterStatusMessage.StorageClusterStatus.NodeOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusMessage.StorageClusterStatus.Region - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region
- StorageClusterStatusMessage.StorageClusterStatus.Region.Builder - Class in org.apache.hadoop.hbase.rest.protobuf.generated
-
Protobuf type org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region
- StorageClusterStatusMessage.StorageClusterStatus.RegionOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusMessage.StorageClusterStatusOrBuilder - Interface in org.apache.hadoop.hbase.rest.protobuf.generated
-
- StorageClusterStatusModel - Class in org.apache.hadoop.hbase.rest.model
-
Representation of the status of a storage cluster:
- StorageClusterStatusModel() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Default constructor
- StorageClusterStatusModel.Node - Class in org.apache.hadoop.hbase.rest.model
-
Represents a region server.
- StorageClusterStatusModel.Node() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Default constructor
- StorageClusterStatusModel.Node(String, long) - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Constructor
- StorageClusterStatusModel.Node.Region - Class in org.apache.hadoop.hbase.rest.model
-
Represents a region hosted on a region server.
- StorageClusterStatusModel.Node.Region() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Default constructor
- StorageClusterStatusModel.Node.Region(byte[]) - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Constructor
- StorageClusterStatusModel.Node.Region(byte[], int, int, int, int, int, long, long, int, int, int, long, long) - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node.Region
-
Constructor
- StorageClusterStatusResource - Class in org.apache.hadoop.hbase.rest
-
- StorageClusterStatusResource() - Constructor for class org.apache.hadoop.hbase.rest.StorageClusterStatusResource
-
Constructor
- StorageClusterVersionModel - Class in org.apache.hadoop.hbase.rest.model
-
Simple representation of the version of the storage cluster
- StorageClusterVersionModel() - Constructor for class org.apache.hadoop.hbase.rest.model.StorageClusterVersionModel
-
- StorageClusterVersionResource - Class in org.apache.hadoop.hbase.rest
-
- StorageClusterVersionResource() - Constructor for class org.apache.hadoop.hbase.rest.StorageClusterVersionResource
-
Constructor
- store - Variable in class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
-
- store - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
-
- Store - Interface in org.apache.hadoop.hbase.regionserver
-
Interface for objects that hold a column family in a Region.
- store - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- store(ByteRange) - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
-
- STORE_COMPLETE_SEQUENCE_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- STORE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STORE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STORE_ENGINE_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
The name of the configuration parameter that specifies the class of
a store engine that is used to manage and compact HBase store files.
- STORE_FILE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse
-
- STORE_FILE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- STORE_FILES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles
-
- STORE_FLUSHES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- STORE_HOME_DIR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor
-
- STORE_HOME_DIR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor
-
- STORE_HOME_DIR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor
-
- STORE_LAST_FLUSHED_SEQUENCE_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse
-
- STORE_LIMIT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- STORE_LIMIT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- STORE_OFFSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- STORE_OFFSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- STORE_SEQUENCE_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds
-
- STORE_UNCOMPRESSED_SIZE_MB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- storeConfigInfo - Variable in class org.apache.hadoop.hbase.regionserver.compactions.CompactionPolicy
-
- StoreConfigInformation - Interface in org.apache.hadoop.hbase.regionserver
-
A more restricted interface for HStore.
- StoreEngine<SF extends org.apache.hadoop.hbase.regionserver.StoreFlusher,CP extends CompactionPolicy,C extends Compactor,SFM extends StoreFileManager> - Class in org.apache.hadoop.hbase.regionserver
-
StoreEngine is a factory that can create the objects necessary for HStore to operate.
- StoreEngine() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- StoreFile - Class in org.apache.hadoop.hbase.regionserver
-
A Store data file.
- StoreFile(FileSystem, Path, Configuration, CacheConfig, BloomType) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile
-
Constructor, loads a reader and it's indices, etc.
- StoreFile(FileSystem, StoreFileInfo, Configuration, CacheConfig, BloomType) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile
-
Constructor, loads a reader and it's indices, etc.
- StoreFile(StoreFile) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile
-
Clone
- storeFile(HRegionInfo, String, SnapshotProtos.SnapshotRegionManifest.StoreFile) - Method in interface org.apache.hadoop.hbase.snapshot.SnapshotReferenceUtil.StoreFileVisitor
-
- storeFile(String, String, String) - Method in interface org.apache.hadoop.hbase.util.FSVisitor.StoreFileVisitor
-
- StoreFile.Comparators - Class in org.apache.hadoop.hbase.regionserver
-
Useful comparators for comparing StoreFiles.
- StoreFile.Comparators() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Comparators
-
- StoreFile.Reader - Class in org.apache.hadoop.hbase.regionserver
-
Reader for a StoreFile.
- StoreFile.Reader(FileSystem, Path, CacheConfig, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- StoreFile.Reader(FileSystem, Path, FSDataInputStreamWrapper, long, CacheConfig, Configuration) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- StoreFile.Writer - Class in org.apache.hadoop.hbase.regionserver
-
A StoreFile writer.
- StoreFile.WriterBuilder - Class in org.apache.hadoop.hbase.regionserver
-
- StoreFile.WriterBuilder(Configuration, CacheConfig, FileSystem) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.WriterBuilder
-
- STOREFILE_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STOREFILE_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STOREFILE_INDEX_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STOREFILE_INDEX_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STOREFILE_INDEX_SIZE_MB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- STOREFILE_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STOREFILE_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- STOREFILE_SIZE_MB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- STOREFILEINDEXSIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- StoreFileInfo - Class in org.apache.hadoop.hbase.regionserver
-
Describe a StoreFile (hfile, reference, link)
- StoreFileInfo(Configuration, FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info
- StoreFileInfo(Configuration, FileSystem, FileStatus) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info
- StoreFileInfo(Configuration, FileSystem, FileStatus, HFileLink) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info from an HFileLink
- StoreFileInfo(Configuration, FileSystem, FileStatus, Reference) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileInfo
-
Create a Store File Info from an HFileLink
- storeFileManager - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- StoreFileManager - Interface in org.apache.hadoop.hbase.regionserver
-
Manages the store files and basic metadata about that that determines the logical structure
(e.g.
- StorefileRefresherChore - Class in org.apache.hadoop.hbase.regionserver
-
A chore for refreshing the store files for secondary regions hosted in the region server.
- StorefileRefresherChore(int, boolean, HRegionServer, Stoppable) - Constructor for class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
-
- STOREFILES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- STOREFILES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- StoreFileScanner - Class in org.apache.hadoop.hbase.regionserver
-
KeyValueScanner adaptor over the Reader.
- StoreFileScanner(StoreFile.Reader, HFileScanner, boolean, boolean, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFileScanner
-
- STOREFILESIZEMB_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- storeFlusher - Variable in class org.apache.hadoop.hbase.regionserver.StoreEngine
-
- storeLimit - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- storeOffset - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- stores - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- STORES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- STORES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor
-
- STORES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor
-
- STORES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Region
-
- StoreScanner - Class in org.apache.hadoop.hbase.regionserver
-
Scanner scans both the memstore and the Store.
- StoreScanner(Store, boolean, Scan, NavigableSet<byte[]>, long, int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
An internal constructor.
- StoreScanner(Store, ScanInfo, Scan, NavigableSet<byte[]>, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Opens a scanner across memstore, snapshot, and all StoreFiles.
- StoreScanner(Store, ScanInfo, Scan, List<? extends KeyValueScanner>, ScanType, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Used for compactions.
- StoreScanner(Store, ScanInfo, Scan, List<? extends KeyValueScanner>, long, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StoreScanner
-
Used for compactions that drop deletes from a limited range of rows.
- STORESCANNER_PARALLEL_SEEK_ENABLE - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- StoreUtils - Class in org.apache.hadoop.hbase.regionserver
-
Utility functions for region server storage layer.
- StoreUtils() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreUtils
-
- StreamUtils - Class in org.apache.hadoop.hbase.io.util
-
- StreamUtils() - Constructor for class org.apache.hadoop.hbase.io.util.StreamUtils
-
- STRING - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
String overhead
- STRING_VIS_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
-
- stringify(Class[]) - Static method in class org.apache.hadoop.hbase.util.Classes
-
- stringifyFilter(Filter) - Static method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
- Strings - Class in org.apache.hadoop.hbase.util
-
Utility for Strings.
- Strings() - Constructor for class org.apache.hadoop.hbase.util.Strings
-
- StringUtils - Class in org.apache.hadoop.hbase.procedure2.util
-
- STRIPE_END_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- STRIPE_START_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
The file metadata fields that contain the stripe information.
- StripeCompactionPolicy - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Stripe store implementation of compaction policy.
- StripeCompactionPolicy(Configuration, StoreConfigInformation, StripeStoreConfig) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
-
- StripeCompactionPolicy.StripeCompactionRequest - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Stripe compaction request wrapper.
- StripeCompactionPolicy.StripeCompactionRequest(CompactionRequest) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy.StripeCompactionRequest
-
- StripeCompactionPolicy.StripeInformationProvider - Interface in org.apache.hadoop.hbase.regionserver.compactions
-
The information about stripes that the policy needs to do its stuff
- StripeCompactor - Class in org.apache.hadoop.hbase.regionserver.compactions
-
This is the placeholder for stripe compactor.
- StripeCompactor(Configuration, Store) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactor
-
- StripeMultiFileWriter - Class in org.apache.hadoop.hbase.regionserver
-
Base class for cell sink that separates the provided cells into multiple files.
- StripeMultiFileWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- StripeMultiFileWriter.BoundaryMultiWriter - Class in org.apache.hadoop.hbase.regionserver
-
MultiWriter that separates the cells based on fixed row-key boundaries.
- StripeMultiFileWriter.BoundaryMultiWriter(List<byte[]>, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- StripeMultiFileWriter.SizeMultiWriter - Class in org.apache.hadoop.hbase.regionserver
-
MultiWriter that separates the cells based on target cell number per file and file count.
- StripeMultiFileWriter.SizeMultiWriter(int, long, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- StripeMultiFileWriter.WriterFactory - Interface in org.apache.hadoop.hbase.regionserver
-
- StripeStoreConfig - Class in org.apache.hadoop.hbase.regionserver
-
Configuration class for stripe store and compactions.
- StripeStoreConfig(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreConfig
-
- StripeStoreEngine - Class in org.apache.hadoop.hbase.regionserver
-
The storage engine that implements the stripe-based store/compaction scheme.
- StripeStoreEngine() - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreEngine
-
- StripeStoreFileManager - Class in org.apache.hadoop.hbase.regionserver
-
Stripe implementation of StoreFileManager.
- StripeStoreFileManager(KeyValue.KVComparator, Configuration, StripeStoreConfig) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- StripeStoreFlusher - Class in org.apache.hadoop.hbase.regionserver
-
Stripe implementation of StoreFlusher.
- StripeStoreFlusher(Configuration, Store, StripeCompactionPolicy, StripeStoreFileManager) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher
-
- StripeStoreFlusher.BoundaryStripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
-
Stripe flush request wrapper based on boundaries.
- StripeStoreFlusher.BoundaryStripeFlushRequest(List<byte[]>) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.BoundaryStripeFlushRequest
-
- StripeStoreFlusher.SizeStripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
-
Stripe flush request wrapper based on size.
- StripeStoreFlusher.SizeStripeFlushRequest(int, long) - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.SizeStripeFlushRequest
-
- StripeStoreFlusher.StripeFlushRequest - Class in org.apache.hadoop.hbase.regionserver
-
Stripe flush request wrapper that writes a non-striped file.
- StripeStoreFlusher.StripeFlushRequest() - Constructor for class org.apache.hadoop.hbase.regionserver.StripeStoreFlusher.StripeFlushRequest
-
- STRONG_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Consistency
-
STRONG = 0;
- strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.HexStringSplit
-
- strToRow(String) - Method in interface org.apache.hadoop.hbase.util.RegionSplitter.SplitAlgorithm
-
- strToRow(String) - Method in class org.apache.hadoop.hbase.util.RegionSplitter.UniformSplit
-
- Struct - Class in org.apache.hadoop.hbase.types
-
Struct
is a simple
DataType
for implementing "compound
rowkey" and "compound qualifier" schema design strategies.
- Struct(DataType[]) - Constructor for class org.apache.hadoop.hbase.types.Struct
-
Create a new Struct
instance defined as the sequence of
HDataType
s in memberTypes
.
- StructBuilder - Class in org.apache.hadoop.hbase.types
-
A helper for building
Struct
instances.
- StructBuilder() - Constructor for class org.apache.hadoop.hbase.types.StructBuilder
-
Create an empty StructBuilder
.
- StructIterator - Class in org.apache.hadoop.hbase.types
-
An
Iterator
over encoded
Struct
members.
- StructIterator(PositionedByteRange, DataType[]) - Constructor for class org.apache.hadoop.hbase.types.StructIterator
-
Construct StructIterator
over the values encoded in src
using the specified types
definition.
- stub - Variable in class org.apache.hadoop.hbase.client.RegionAdminServiceCallable
-
- subMap(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
- submit(RetryingCallable<V>, int, int) - Method in class org.apache.hadoop.hbase.client.ResultBoundedCompletionService
-
- submit(EventHandler) - Method in class org.apache.hadoop.hbase.executor.ExecutorService
-
- submit(Callable<V>) - Method in class org.apache.hadoop.hbase.util.BoundedCompletionService
-
- submitAndWaitProcedure(ProcedureExecutor<MasterProcedureEnv>, Procedure) - Static method in class org.apache.hadoop.hbase.master.procedure.ProcedureSyncWait
-
- submitMaxNodeDepthCandidate(int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- submitProcedure(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Add a new root-procedure to the executor.
- submitProcedure(Procedure, long, long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Add a new root-procedure to the executor.
- submitSubprocedure(Subprocedure) - Method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Submit an subprocedure for execution.
- submitTask(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
- submitTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- Subprocedure - Class in org.apache.hadoop.hbase.procedure
-
Distributed procedure member's Subprocedure.
- Subprocedure(ProcedureMember, String, ForeignExceptionDispatcher, long, long) - Constructor for class org.apache.hadoop.hbase.procedure.Subprocedure
-
- Subprocedure.SubprocedureImpl - Class in org.apache.hadoop.hbase.procedure
-
Empty Subprocedure for testing.
- Subprocedure.SubprocedureImpl(ProcedureMember, String, ForeignExceptionDispatcher, long, long) - Constructor for class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- SubprocedureFactory - Interface in org.apache.hadoop.hbase.procedure
-
- subSet(Cell, Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- subSet(Cell, boolean, Cell, boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- subSet(E, E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- SUBSTR_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.SubstringComparator
-
- SubstringComparator - Class in org.apache.hadoop.hbase.filter
-
This comparator is for use with SingleColumnValueFilter, for filtering based on
the value of a given column.
- SubstringComparator(String) - Constructor for class org.apache.hadoop.hbase.filter.SubstringComparator
-
Constructor
- substringType - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
SubstringType byte array
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- success - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- SUCCESSFUL_DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- SUCCESSFUL_GET_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- SUCCESSFUL_PUT_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- SUCCESSFUL_SCAN_KEY - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- sum(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
It sums up the value returned from various regions.
- sum(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
It sums up the value returned from various regions.
- summarize() - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- sumOfMillisSecBetweenNexts - Variable in class org.apache.hadoop.hbase.client.metrics.ScanMetrics
-
sum of milliseconds between sequential next calls
- SUPERUSER_CONF_KEY - Static variable in class org.apache.hadoop.hbase.security.Superusers
-
Configuration key for superusers
- Superusers - Class in org.apache.hadoop.hbase.security
-
Keeps lists of superusers and super groups loaded from HBase configuration,
checks if certain user is regarded as superuser.
- supportsAutoLoading() - Method in interface org.apache.hadoop.hbase.util.BloomFilter
-
- supportsAutoLoading() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- supportsAutoLoading() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilter
-
- suspendEncoding() - Method in class org.apache.hadoop.hbase.util.Base64.Base64OutputStream
-
Suspends encoding of the stream.
- SWITCH_TO_SIMPLE_AUTH - Static variable in class org.apache.hadoop.hbase.security.SaslUtil
-
- sync() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.ByteBufferIOEngine
-
No operation for the sync in the memory IO engine
- sync() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
-
Sync the data to file after writing
- sync() - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.IOEngine
-
Sync the data to IOEngine after writing
- sync() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- sync(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- sync() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- sync() - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Sync what we have in the WAL.
- sync(long) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Sync the WAL if the txId was not already sync'd.
- sync() - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
-
- sync(String, AsyncCallback.VoidCallback, Object) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
- sync(String) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
Forces a synchronization of this ZooKeeper client connection.
- SYNC_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SYNC_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- SYNC_WAL_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Durability
-
SYNC_WAL = 3;
- SYNCHRONOUS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetBalancerRunningRequest
-
- syncSlots(FSDataOutputStream, ByteSlot[], int, int) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- SYSTEM_LABEL - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityUtils
-
- SYSTEM_NAMESPACE - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- SYSTEM_NAMESPACE_NAME - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
System namespace name.
- SYSTEM_NAMESPACE_NAME_STR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- SYSTEMTABLE_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- SystemTableWALEntryFilter - Class in org.apache.hadoop.hbase.replication
-
Skips WAL edits for all System tables including META
- SystemTableWALEntryFilter() - Constructor for class org.apache.hadoop.hbase.replication.SystemTableWALEntryFilter
-