- C - Static variable in class org.apache.hadoop.hbase.coprocessor.TestRegionObserverInterface
-
- 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 - 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, 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.
- cacheOnWrite - Variable in class org.apache.hadoop.hbase.io.hfile.TestLazyDataBlockDecompression
-
- 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
-
- CacheTestUtils - Class in org.apache.hadoop.hbase.io.hfile
-
- CacheTestUtils() - Constructor for class org.apache.hadoop.hbase.io.hfile.CacheTestUtils
-
- CacheTestUtils.ByteArrayCacheable - Class in org.apache.hadoop.hbase.io.hfile
-
- 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, 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, 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, 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.mttr.IntegrationTestMTTR.LoadCallable
-
- 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(Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- callExecService(Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.MasterCoprocessorRpcChannel
-
- callExecService(Descriptors.MethodDescriptor, Message, Message) - Method in class org.apache.hadoop.hbase.ipc.RegionCoprocessorRpcChannel
-
- callExecService(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(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.RowCountService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.ColumnAggregationService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.ColumnAggregationServiceWithErrors
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.ColumnAggregationServiceNullResponse
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService
-
- 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, <any>) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient.RpcChannelImplementation
-
- callMethod(Descriptors.MethodDescriptor, RpcController, Message, Message, <any>) - Method in class org.apache.hadoop.hbase.ipc.CoprocessorRpcChannel
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestDelayedService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestRpcServiceProtos.TestProtobufRpcProto
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MultiRowMutationService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStatusService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RowProcessorProtos.RowProcessorService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
-
- callMethod(com.google.protobuf.Descriptors.MethodDescriptor, com.google.protobuf.RpcController, com.google.protobuf.Message, <any>) - 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
-
- CALM - Static variable in class org.apache.hadoop.hbase.chaos.factories.MonkeyFactory
-
- CalmChaosMonkey - Class in org.apache.hadoop.hbase.chaos.monkies
-
Chaos Monkey that does nothing.
- CalmChaosMonkey() - Constructor for class org.apache.hadoop.hbase.chaos.monkies.CalmChaosMonkey
-
- CalmMonkeyFactory - Class in org.apache.hadoop.hbase.chaos.factories
-
Factory to create a calm ChaosMonkey.
- CalmMonkeyFactory() - Constructor for class org.apache.hadoop.hbase.chaos.factories.CalmMonkeyFactory
-
- 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.RegionServerStdOutSink - Class in org.apache.hadoop.hbase.tool
-
- Canary.Sink - Interface in org.apache.hadoop.hbase.tool
-
- Canary.StdOutSink - Class in org.apache.hadoop.hbase.tool
-
- 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 org.apache.hadoop.util.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
-
- cancelCompaction(Object) - Method in class org.apache.hadoop.hbase.regionserver.StatefulStoreMockMaker
-
- cancelCompaction(Object) - Method in class org.apache.hadoop.hbase.regionserver.TestCompaction.BlockingStoreMockMaker
-
- 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
-
- canCloseSingleton() - Method in class org.apache.hadoop.hbase.wal.TestWALFactory
-
- 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
-
- captureLogs(Log) - Static method in class org.apache.hadoop.hbase.GenericTestUtils.LogCapturer
-
- 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.
- 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
- 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
-
- CellScannerButNoCodecException() - Constructor for exception org.apache.hadoop.hbase.ipc.IPCUtil.CellScannerButNoCodecException
-
- 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
-
- CellSetModelStream() - Constructor for class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
-
- CellSetModelStream(ArrayList<RowModel>) - Constructor for class org.apache.hadoop.hbase.rest.TableScanResource.CellSetModelStream
-
- 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 - Static variable in class org.apache.hadoop.hbase.util.TestMiniClusterLoadSequential
-
- 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
-
- CFA - Static variable in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- CFB - Static variable in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- 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
-
- ChangeBloomFilterAction - Class in org.apache.hadoop.hbase.chaos.actions
-
Action that tries to adjust the bloom filter setting on all the columns of a
table
- ChangeBloomFilterAction(TableName) - Constructor for class org.apache.hadoop.hbase.chaos.actions.ChangeBloomFilterAction
-
- ChangeBloomFilterAction(int, TableName) - Constructor for class org.apache.hadoop.hbase.chaos.actions.ChangeBloomFilterAction
-
- ChangeCompressionAction - Class in org.apache.hadoop.hbase.chaos.actions
-
Action that changes the compression algorithm on a column family from a list of tables.
- ChangeCompressionAction(TableName) - Constructor for class org.apache.hadoop.hbase.chaos.actions.ChangeCompressionAction
-
- ChangedReadersObserver - Interface in org.apache.hadoop.hbase.regionserver
-
If set of MapFile.Readers in Store change, implementors are notified.
- ChangeEncodingAction - Class in org.apache.hadoop.hbase.chaos.actions
-
Action that changes the encoding on a column family from a list of tables.
- ChangeEncodingAction(TableName) - Constructor for class org.apache.hadoop.hbase.chaos.actions.ChangeEncodingAction
-
- ChangeVersionsAction - Class in org.apache.hadoop.hbase.chaos.actions
-
Action that changes the number of versions on a column family from a list of tables.
- ChangeVersionsAction(TableName) - Constructor for class org.apache.hadoop.hbase.chaos.actions.ChangeVersionsAction
-
- 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
-
- CHAOS_MONKEY_DELAY_KEY - Static variable in class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas
-
- CHAOS_MONKEY_PROPS - Static variable in class org.apache.hadoop.hbase.chaos.util.ChaosMonkeyRunner
-
- CHAOS_MONKEY_PROPS - Static variable in class org.apache.hadoop.hbase.IntegrationTestBase
-
- ChaosMonkey - Class in org.apache.hadoop.hbase.chaos.monkies
-
A utility to injects faults in a running cluster.
- ChaosMonkey() - Constructor for class org.apache.hadoop.hbase.chaos.monkies.ChaosMonkey
-
- ChaosMonkeyRunner - Class in org.apache.hadoop.hbase.chaos.util
-
- ChaosMonkeyRunner() - Constructor for class org.apache.hadoop.hbase.chaos.util.ChaosMonkeyRunner
-
- CHARSET_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.RegexStringComparator
-
- check(Put) - Method in class org.apache.hadoop.hbase.constraint.AllFailConstraint
-
- check(Put) - Method in class org.apache.hadoop.hbase.constraint.AllPassConstraint
-
- check(Put) - Method in class org.apache.hadoop.hbase.constraint.CheckConfigurationConstraint
-
- check(Put) - Method in interface org.apache.hadoop.hbase.constraint.Constraint
-
Check a
Put
to ensure it is valid for the table.
- check(Put) - Method in class org.apache.hadoop.hbase.constraint.RuntimeFailConstraint
-
- check(Put) - Method in class org.apache.hadoop.hbase.constraint.TestConstraint.CheckWasRunConstraint
-
- check(Put) - Method in class org.apache.hadoop.hbase.constraint.TestConstraints.AlsoWorks
-
- check(Put) - Method in class org.apache.hadoop.hbase.constraint.WorksConstraint
-
- 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, <any>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, <any>) - 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() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndDelete
-
- checkAndDelete(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- checkAndDelete_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- checkAndDelete_args(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- checkAndDelete_args(THBaseService.checkAndDelete_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
Performs a deep copy on other.
- checkAndDelete_call(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TDelete, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndDelete_call
-
- checkAndDelete_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- checkAndDelete_result(boolean, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- checkAndDelete_result(THBaseService.checkAndDelete_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
Performs a deep copy on other.
- checkAndDeleteJson(String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- checkAndDeleteJson(String, String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- checkAndDeletePB(String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- checkAndDeleteValuePB(String, String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- checkAndDeleteXML(String, String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- checkAndDeleteXML(String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- 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>, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>, <any>) - 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() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.checkAndPut
-
- 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, <any>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, <any>) - 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() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.checkAndPut
-
- checkAndPut(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- checkAndPut_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- checkAndPut_args(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- checkAndPut_args(Hbase.checkAndPut_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
Performs a deep copy on other.
- checkAndPut_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- checkAndPut_args(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- checkAndPut_args(THBaseService.checkAndPut_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
Performs a deep copy on other.
- checkAndPut_call(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, Mutation, Map<ByteBuffer, ByteBuffer>, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.checkAndPut_call
-
- checkAndPut_call(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, TPut, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.checkAndPut_call
-
- checkAndPut_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- checkAndPut_result(boolean, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- checkAndPut_result(Hbase.checkAndPut_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
Performs a deep copy on other.
- checkAndPut_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- checkAndPut_result(boolean, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- checkAndPut_result(THBaseService.checkAndPut_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
Performs a deep copy on other.
- checkAndPutValuePB(String, String, String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- checkAndPutValuePB(String, String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- checkAndPutValueXML(String, String, String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- checkAndPutValueXML(String, String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- 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.
- checkClasses() - Method in class org.apache.hadoop.hbase.TestCheckTestClasses
-
Throws an assertion if we find a test class without category (small/medium/large/integration).
- 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.
- CheckConfigurationConstraint - Class in org.apache.hadoop.hbase.constraint
-
Test Constraint to check to make sure the configuration is set
- CheckConfigurationConstraint() - Constructor for class org.apache.hadoop.hbase.constraint.CheckConfigurationConstraint
-
- 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.
- checkExit(int) - Method in class org.apache.hadoop.hbase.util.LauncherSecurityManager
-
- 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'
- checkGlobalPerms(HBaseTestingUtility, Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- 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
-
- checkInit() - Method in class org.apache.hadoop.hbase.ResourceChecker
-
- 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
-
- checkModel(CellModel) - Method in class org.apache.hadoop.hbase.rest.model.TestCellModel
-
- checkModel(CellSetModel) - Method in class org.apache.hadoop.hbase.rest.model.TestCellSetModel
-
- checkModel(ColumnSchemaModel) - Method in class org.apache.hadoop.hbase.rest.model.TestColumnSchemaModel
-
- checkModel(T) - Method in class org.apache.hadoop.hbase.rest.model.TestModelBase
-
- checkModel(RowModel) - Method in class org.apache.hadoop.hbase.rest.model.TestRowModel
-
- checkModel(ScannerModel) - Method in class org.apache.hadoop.hbase.rest.model.TestScannerModel
-
- checkModel(StorageClusterStatusModel) - Method in class org.apache.hadoop.hbase.rest.model.TestStorageClusterStatusModel
-
- checkModel(StorageClusterVersionModel) - Method in class org.apache.hadoop.hbase.rest.model.TestStorageClusterVersionModel
-
- checkModel(TableInfoModel) - Method in class org.apache.hadoop.hbase.rest.model.TestTableInfoModel
-
- checkModel(TableListModel) - Method in class org.apache.hadoop.hbase.rest.model.TestTableListModel
-
- checkModel(TableRegionModel) - Method in class org.apache.hadoop.hbase.rest.model.TestTableRegionModel
-
- checkModel(TableSchemaModel) - Method in class org.apache.hadoop.hbase.rest.model.TestTableSchemaModel
-
- checkModel(TableSchemaModel, String) - Method in class org.apache.hadoop.hbase.rest.model.TestTableSchemaModel
-
- checkModel(VersionModel) - Method in class org.apache.hadoop.hbase.rest.model.TestVersionModel
-
- checkMultimapEqual(<any>, <any>) - Method in class org.apache.hadoop.hbase.security.access.TestTablePermissions
-
- checkNamespaceTableAndRegionQuota(TableName, int) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
-
- checkNodeCount(int) - Method in class org.apache.hadoop.hbase.IntegrationTestingUtility
-
Checks whether we have more than numSlaves nodes.
- checkNoError() - Method in class org.apache.hadoop.hbase.regionserver.TestHRegion.FlushThread
-
- checkNoError() - Method in class org.apache.hadoop.hbase.regionserver.TestHRegion.PutThread
-
- 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.
- checkPermission(Permission, Object) - Method in class org.apache.hadoop.hbase.util.LauncherSecurityManager
-
- checkPermission(Permission) - Method in class org.apache.hadoop.hbase.util.LauncherSecurityManager
-
- checkPermissions(com.google.protobuf.RpcController, AccessControlProtos.CheckPermissionsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.BlockingInterface
-
- checkPermissions(com.google.protobuf.RpcController, AccessControlProtos.CheckPermissionsRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
-
rpc CheckPermissions(.CheckPermissionsRequest) returns (.CheckPermissionsResponse);
- checkPermissions(com.google.protobuf.RpcController, AccessControlProtos.CheckPermissionsRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Interface
-
rpc CheckPermissions(.CheckPermissionsRequest) returns (.CheckPermissionsResponse);
- checkPermissions(com.google.protobuf.RpcController, AccessControlProtos.CheckPermissionsRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService.Stub
-
- checkPermissions(RpcController, AccessControlProtos.CheckPermissionsRequest, <any>) - 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.
- checkRegionIsClosed(HBaseTestingUtility, HRegionServer, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.TestRegionServerNoMaster
-
- checkRegionIsOpened(HBaseTestingUtility, HRegionServer, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.TestRegionServerNoMaster
-
- 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
-
- checkStatistics(KeyValueScanner, int) - Method in class org.apache.hadoop.hbase.regionserver.DataBlockEncodingTool
-
Check statistics for given HFile for different data block encoders.
- 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.
- checksumRows(Table) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Return an md5 digest of the entire contents of a table.
- 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
-
- checkTableList(Hbase.Iface) - Static method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
- 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
- checkTablePerms(Configuration, TableName, byte[], byte[], Permission.Action...) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- checkTablePerms(Configuration, TableName, Permission...) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- checkTables(Collection<Path>) - Method in class org.apache.hadoop.hbase.util.hbck.HFileCorruptionChecker
-
Check the specified table dirs for bad hfiles.
- checkTagPresence - Static variable in class org.apache.hadoop.hbase.regionserver.TestTags.TestCoprocessorForTags
-
- 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.
- checkValueJSON(String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- checkValuePB(String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- checkValueXML(String, String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- checkValueXML(String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- 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.
- CheckWasRunConstraint() - Constructor for class org.apache.hadoop.hbase.constraint.TestConstraint.CheckWasRunConstraint
-
- 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.ClusterStatusPublisher
-
- chore() - Method in class org.apache.hadoop.hbase.master.normalizer.RegionNormalizerChore
-
- 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
- chore() - Method in class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.CountingChore
-
- chore() - Method in class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.DoNothingChore
-
- chore() - Method in class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.FailInitialChore
-
- chore() - Method in class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.SleepingChore
-
- chore() - Method in class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.SlowChore
-
- 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 - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- 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
-
- ClassFinder - Class in org.apache.hadoop.hbase
-
A class that finds a set of classes that are locally accessible
(from .class or .jar files), and satisfy the conditions that are
imposed by name and class filters provided by the user.
- ClassFinder() - Constructor for class org.apache.hadoop.hbase.ClassFinder
-
- ClassFinder(ClassFinder.ResourcePathFilter, ClassFinder.FileNameFilter, ClassFinder.ClassFilter) - Constructor for class org.apache.hadoop.hbase.ClassFinder
-
- ClassFinder.And - Class in org.apache.hadoop.hbase
-
- ClassFinder.ClassFilter - Interface in org.apache.hadoop.hbase
-
- ClassFinder.FileNameFilter - Interface in org.apache.hadoop.hbase
-
- ClassFinder.Not - Class in org.apache.hadoop.hbase
-
- ClassFinder.ResourcePathFilter - Interface in org.apache.hadoop.hbase
-
- 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.
- ClassLoaderTestHelper - Class in org.apache.hadoop.hbase.util
-
Some utilities to help class loader testing
- ClassLoaderTestHelper() - Constructor for class org.apache.hadoop.hbase.util.ClassLoaderTestHelper
-
- classSetUp() - Static method in class org.apache.hadoop.hbase.regionserver.TestMetricsRegionServer
-
- 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
-
- ClassTestFinder - Class in org.apache.hadoop.hbase
-
ClassFinder that is pre-configured with filters that will only allow test classes.
- ClassTestFinder() - Constructor for class org.apache.hadoop.hbase.ClassTestFinder
-
- ClassTestFinder(Class<?>) - Constructor for class org.apache.hadoop.hbase.ClassTestFinder
-
- ClassTestFinder.TestClassFilter - Class in org.apache.hadoop.hbase
-
- ClassTestFinder.TestFileNameFilter - Class in org.apache.hadoop.hbase
-
- clazz - Variable in class org.apache.hadoop.hbase.rest.model.TestModelBase
-
- 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() - Method in class org.apache.hadoop.hbase.constraint.TestConstraint
-
- cleanup() - Static method in class org.apache.hadoop.hbase.http.jmx.TestJMXJsonServlet
-
- cleanup() - Static method in class org.apache.hadoop.hbase.http.TestHttpServer
-
- cleanup() - Static method in class org.apache.hadoop.hbase.http.TestSSLHttpServer
-
- cleanUp() - Method in class org.apache.hadoop.hbase.IntegrationTestBase
-
- cleanUp() - Method in class org.apache.hadoop.hbase.IntegrationTestIngestWithEncryption
-
- cleanUp() - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestTableSnapshotInputFormat
-
- cleanup(Context) - Method in class org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier
-
- cleanup() - Method in class org.apache.hadoop.hbase.mapreduce.TestImportExport
-
- cleanup(Context) - Method in class org.apache.hadoop.hbase.mapreduce.TestMultiTableInputFormat.ScanReducer
-
- cleanup(Context) - Method in class org.apache.hadoop.hbase.mapreduce.TestTableInputFormatScanBase.ScanReducer
-
- cleanup(Context) - Method in class org.apache.hadoop.hbase.mapreduce.TestTableSnapshotInputFormat.TestTableSnapshotReducer
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.cleaner.TestCleanerChore
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- cleanup() - Method in class org.apache.hadoop.hbase.master.handler.TestTableDeleteFamilyHandler
-
- cleanup() - Static method in class org.apache.hadoop.hbase.master.snapshot.TestSnapshotHFileCleaner
-
- cleanup() - Static method in class org.apache.hadoop.hbase.master.snapshot.TestSnapshotLogCleaner
-
- 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() - Method in class org.apache.hadoop.hbase.namespace.TestNamespaceAuditor
-
- 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.SimpleRSProcedureManager.SimpleSubprocedure
-
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
- cleanup(Context) - Method in class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.LoadMapper
-
- cleanUp() - Method in class org.apache.hadoop.hbase.TestNodeHealthCheckChore
-
- cleanupBulkLoad(String) - Method in class org.apache.hadoop.hbase.client.coprocessor.SecureBulkLoadClient
-
- cleanupBulkLoad(com.google.protobuf.RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.BlockingInterface
-
- cleanupBulkLoad(com.google.protobuf.RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService
-
rpc CleanupBulkLoad(.CleanupBulkLoadRequest) returns (.CleanupBulkLoadResponse);
- cleanupBulkLoad(com.google.protobuf.RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Interface
-
rpc CleanupBulkLoad(.CleanupBulkLoadRequest) returns (.CleanupBulkLoadResponse);
- cleanupBulkLoad(com.google.protobuf.RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadService.Stub
-
- cleanupBulkLoad(RpcController, SecureBulkLoadProtos.CleanupBulkLoadRequest, <any>) - 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.
- cleanUpCluster() - Method in class org.apache.hadoop.hbase.IntegrationTestBase
-
- cleanUpCluster() - Method in class org.apache.hadoop.hbase.IntegrationTestDDLMasterFailover
-
- cleanUpCluster() - Method in class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedList
-
- cleanUpCluster() - Method in class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify
-
- cleanupDataTestDirOnTestFS() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Cleans the test data directory on the test filesystem.
- cleanupDataTestDirOnTestFS(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Cleans a subdirectory under the test data directory on the test filesystem.
- cleanupFiles() - Method in class org.apache.hadoop.hbase.master.snapshot.TestSnapshotFileCache
-
- cleanupFS() - Method in class org.apache.hadoop.hbase.snapshot.TestSnapshotDescriptionUtils
-
- cleanupJob(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- cleanUpMonkey() - Method in class org.apache.hadoop.hbase.IntegrationTestBase
-
- cleanUpMonkey(String) - Method in class org.apache.hadoop.hbase.IntegrationTestBase
-
- cleanupSnapshot(Admin, byte[]) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
- cleanupSnapshot(Admin, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
- cleanupSSLConfig(String, String) - Static method in class org.apache.hadoop.hbase.http.ssl.KeyStoreTestUtil
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.backup.example.TestZooKeeperTableArchiveClient
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.backup.TestHFileArchiving
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.client.TestSnapshotCloneIndependence
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.client.TestSnapshotFromClient
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.client.TestSnapshotMetadata
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.master.cleaner.TestSnapshotFromMaster
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.master.procedure.TestAddColumnFamilyProcedure
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.master.procedure.TestCreateTableProcedure
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.master.procedure.TestDeleteColumnFamilyProcedure
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.master.procedure.TestDeleteTableProcedure
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.master.procedure.TestDisableTableProcedure
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.master.procedure.TestEnableTableProcedure
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.master.procedure.TestModifyColumnFamilyProcedure
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.master.procedure.TestModifyTableProcedure
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.master.procedure.TestProcedureAdmin
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.master.procedure.TestTruncateTableProcedure
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.procedure.TestZKProcedure
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.procedure.TestZKProcedureControllers
-
- cleanupTest() - Static method in class org.apache.hadoop.hbase.snapshot.TestFlushSnapshotFromClient
-
- cleanupTestDir() - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
- cleanupTestDir() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- cleanupTestTable() - Method in class org.apache.hadoop.hbase.coprocessor.TestOpenTableInCoprocessor
-
- 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.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse.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.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyRequestProto.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyResponseProto.Builder
-
- 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.store.ProcedureStoreTracker
-
- 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.IsNormalizerEnabledRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse.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.NormalizeRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse.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.SetNormalizerRunningRequest.Builder
-
- clear() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse.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.RegionNormalizerProtos.RegionNormalizerState.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 class 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 class org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- clear() - Method in class 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 class org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- clear() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- clear() - Method in class 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 class org.apache.hadoop.hbase.util.ConstantDelayQueue
-
- 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;
- 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(com.google.protobuf.RpcController, VisibilityLabelsProtos.SetAuthsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.BlockingInterface
-
- clearAuths(com.google.protobuf.RpcController, VisibilityLabelsProtos.SetAuthsRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService
-
rpc clearAuths(.SetAuthsRequest) returns (.VisibilityLabelsResponse);
- clearAuths(com.google.protobuf.RpcController, VisibilityLabelsProtos.SetAuthsRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.Interface
-
rpc clearAuths(.SetAuthsRequest) returns (.VisibilityLabelsResponse);
- clearAuths(com.google.protobuf.RpcController, VisibilityLabelsProtos.SetAuthsRequest, <any>) - 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(byte[], List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.ExpAsStringVisibilityLabelServiceImpl
-
- 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, <any>) - 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
-
- 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];
- clearCount() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse.Builder
-
required int32 count = 1;
- clearCount() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse.Builder
-
required int32 count = 1;
- clearCounter() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest.Builder
-
required int32 counter = 2;
- 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;
- clearDelay() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg.Builder
-
required bool delay = 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;
- clearDiff() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest.Builder
-
required int32 diff = 1;
- 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;
- clearEnabled() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse.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.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest.Builder
-
required bytes family = 1;
- clearFamily() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest.Builder
-
required bytes family = 1;
- clearFamily() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest.Builder
-
required bytes family = 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.BalanceRequest.Builder
-
optional bool force = 1;
- 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.ipc.protobuf.generated.TestProtos.EchoRequestProto.Builder
-
required string message = 1;
- clearMessage() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto.Builder
-
required string message = 1;
- 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.coprocessor.protobuf.generated.PingProtos.HelloRequest.Builder
-
optional string name = 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.MultiRowMutationProtos.MutateRowsRequest.Builder
-
optional uint64 nonce = 3;
- 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.MultiRowMutationProtos.MutateRowsRequest.Builder
-
optional uint64 nonce_group = 2;
- 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;
- clearNormalizerOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState.Builder
-
optional bool normalizer_on = 1;
- clearNormalizerRan() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse.Builder
-
required bool normalizer_ran = 1;
- 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;
- clearOn() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningRequest.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;
- clearPerson() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
-
required bytes person = 1;
- clearPong() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse.Builder
-
required string pong = 1;
- 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;
- clearPrevNormalizerValue() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse.Builder
-
optional bool prev_normalizer_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.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest.Builder
-
optional bytes qualifier = 2;
- clearQualifier() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest.Builder
-
optional bytes qualifier = 2;
- clearQualifier() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest.Builder
-
optional bytes qualifier = 2;
- 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
-
- clearRegionCache(TableName) - Method in interface org.apache.hadoop.hbase.client.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;
- 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.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse.Builder
-
required int32 response = 1;
- clearResponse() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse.Builder
-
optional string response = 1;
- clearResponse() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse.Builder
-
required int32 response = 1;
- 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.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
-
repeated string result = 3;
- clearResult() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse.Builder
-
repeated string result = 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.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
-
required bytes row = 2;
- clearRow() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest.Builder
-
required bytes row = 1;
- clearRow() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest.Builder
-
required bytes row = 1;
- 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;
- clearRow1() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest.Builder
-
required bytes row1 = 1;
- clearRow2() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest.Builder
-
required bytes row2 = 2;
- 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;
- clearSum() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse.Builder
-
required int64 sum = 1;
- clearSum() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse.Builder
-
required int64 sum = 1;
- clearSum() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse.Builder
-
optional int64 sum = 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.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData.Builder
-
required string table_name = 1;
- 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.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse.Builder
-
required string value = 1;
- 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 - Static variable in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- Client(org.apache.thrift.protocol.TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- Client(org.apache.thrift.protocol.TProtocol, org.apache.thrift.protocol.TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- Client(org.apache.thrift.protocol.TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- Client(org.apache.thrift.protocol.TProtocol, org.apache.thrift.protocol.TProtocol) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- 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
- 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.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.
- ClientScannerIncommon(ResultScanner) - Constructor for class org.apache.hadoop.hbase.HBaseTestCase.ClientScannerIncommon
-
Deprecated.
- ClientService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ClientService
-
- ClientSideCellSetModel() - Constructor for class org.apache.hadoop.hbase.rest.TestTableScan.ClientSideCellSetModel
-
- 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
-
- 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.coprocessor.protobuf.generated.ColumnAggregationProtos.SumRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.SumResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.SumResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.SumResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.RowSwapProcessorResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.TimeoutProcessorResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.HelloResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.NoopResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- clone() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestResponse.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProcedureProtos.TestTableDDLStateData.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoRequestProto.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EchoResponseProto.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyRequestProto.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestProtos.EmptyResponseProto.Builder
-
- 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.IsNormalizerEnabledRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsNormalizerEnabledResponse.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.NormalizeRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.NormalizeResponse.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.SetNormalizerRunningRequest.Builder
-
- clone() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.SetNormalizerRunningResponse.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.RegionNormalizerProtos.RegionNormalizerState.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
- cloneAndAssertOneRetry(String, TableName) - Method in class org.apache.hadoop.hbase.snapshot.TestSnapshotClientRetries
-
- 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.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.DistributedHBaseCluster
-
- close() - Method in class org.apache.hadoop.hbase.fs.HFileSystem
-
Close this filesystem object
- close() - Method in class org.apache.hadoop.hbase.HBaseCluster
-
Closes all the resources held open for this cluster.
- close() - Method in class org.apache.hadoop.hbase.HBaseTestCase.ClientScannerIncommon
-
Deprecated.
- close() - Method in class org.apache.hadoop.hbase.HBaseTestCase.InternalScannerIncommon
-
Deprecated.
- close() - Method in interface org.apache.hadoop.hbase.HBaseTestCase.ScannerIncommon
-
Deprecated.
- 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.mapred.TestTableInputFormat.ExampleVerifier
-
- close() - Method in class org.apache.hadoop.hbase.mapred.TestTableSnapshotInputFormat.TestTableSnapshotReducer
-
- close() - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.FixedRecordReader
-
- 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.MiniHBaseCluster
-
- 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.SimpleRSProcedureManager.SimpleSubprocedurePool
-
Attempt to cleanly shutdown any running tasks - allows currently running tasks to cleanly
finish
- 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.regionserver.wal.SequenceFileLogWriter
-
- 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.PerformanceEvaluation.PeInputFormat.PeRecordReader
-
- 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.util.MultiThreadedAction
-
- close() - Method in class org.apache.hadoop.hbase.wal.BoundedRegionGroupingProvider
-
- close() - Method in class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- close() - Method in class org.apache.hadoop.hbase.wal.IOTestProvider
-
- 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
-
- closeConnection() - Method in class org.apache.hadoop.hbase.test.IntegrationTestReplication.ClusterID
-
- 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;
- closedCount - Variable in class org.apache.hadoop.hbase.regionserver.wal.TestWALActionsListener.DummyWALActionsListener
-
- 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
-
- closeHTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater.HBaseUpdaterThread
-
- closeHTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL
-
- closeHTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter.HBaseWriterThread
-
- closeHTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL.HBaseWriterThreadWithACL
-
- 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(Region) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Close the Region r
.
- closeRegion(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Closes the named region.
- closeRegion(byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Closes the named region.
- closeRegion(com.google.protobuf.RpcController, AdminProtos.CloseRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
-
- closeRegion(com.google.protobuf.RpcController, AdminProtos.CloseRegionRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
rpc CloseRegion(.CloseRegionRequest) returns (.CloseRegionResponse);
- closeRegion(com.google.protobuf.RpcController, AdminProtos.CloseRegionRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
-
rpc CloseRegion(.CloseRegionRequest) returns (.CloseRegionResponse);
- closeRegion(com.google.protobuf.RpcController, AdminProtos.CloseRegionRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Stub
-
- closeRegion(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(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.
- closeRegion(HBaseTestingUtility, HRegionServer, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.TestRegionServerNoMaster
-
- closeRegionAndWAL(Region) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Close both the region r
and it's underlying WAL.
- closeRegionAndWAL(HRegion) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Close both the HRegion r
and it's underlying WAL.
- closeRegionByRow(String, RegionLocator) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Closes the region containing the given row.
- closeRegionByRow(byte[], RegionLocator) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Closes the region containing the given row.
- 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.
- closeRootAndMeta() - Method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
- closeScanner(int, <any>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- closeScanner(int, <any>) - 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() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.closeScanner
-
- closeScanner(int) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- closeScanner_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- closeScanner_args(int) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- closeScanner_args(THBaseService.closeScanner_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
Performs a deep copy on other.
- closeScanner_call(int, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.closeScanner_call
-
- closeScanner_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- closeScanner_result(TIOError, TIllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- closeScanner_result(THBaseService.closeScanner_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
Performs a deep copy on other.
- 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
-
- closeTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
-
- closeTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL.HBaseReaderThreadWithACL
-
- 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 - Variable in class org.apache.hadoop.hbase.chaos.actions.Action
-
- cluster - Variable in class org.apache.hadoop.hbase.IntegrationTestDDLMasterFailover
-
- cluster - Variable in class org.apache.hadoop.hbase.IntegrationTestIngest
-
- Cluster(Map<ServerName, List<HRegionInfo>>, Map<String, Deque<RegionLoad>>, RegionLocationFinder, RackManager) - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
-
- Cluster(Collection<HRegionInfo>, Map<ServerName, List<HRegionInfo>>, Map<String, Deque<RegionLoad>>, RegionLocationFinder, RackManager) - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
-
- 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 - Static variable in class org.apache.hadoop.hbase.rest.PerformanceEvaluation
-
- cluster - Static variable in class org.apache.hadoop.hbase.TestNamespace
-
- 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 HConnection 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
-
- ClusterID(Configuration, String) - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestReplication.ClusterID
-
This creates a new ClusterID wrapper that will automatically build connections and
configurations to be able to talk to the specified cluster
- 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
-
- 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.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.
- cmd - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
This will be removed as we factor out the dependency on command line
- CMD_KEY - Static variable in class org.apache.hadoop.hbase.PerformanceEvaluation.EvaluationMapTask
-
configuration parameter name that contains the command
- CMD_KEY - Static variable in class org.apache.hadoop.hbase.rest.PerformanceEvaluation.EvaluationMapTask
-
configuration parameter name that contains the command
- 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
-
- CodecPerformance - Class in org.apache.hadoop.hbase.codec
-
Do basic codec performance eval.
- CodecPerformance() - Constructor for class org.apache.hadoop.hbase.codec.CodecPerformance
-
- 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_1 - Static variable in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- COLUMN_2 - Static variable in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- COLUMN_3 - Static variable in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- COLUMN_CLIENT - Static variable in class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedList
-
- COLUMN_COUNT - Static variable in class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedList
-
- 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 - Static variable in class org.apache.hadoop.hbase.IntegrationTestManyRegions
-
- COLUMN_NAME - Static variable in class org.apache.hadoop.hbase.rest.model.TestColumnSchemaModel
-
- 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_PREV - Static variable in class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedList
-
- 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
-
- COLUMN_ZERO - Static variable in class org.apache.hadoop.hbase.PerformanceEvaluation
-
- ColumnAggregationEndpoint - Class in org.apache.hadoop.hbase.coprocessor
-
The aggregation implementation at a region.
- ColumnAggregationEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.ColumnAggregationEndpoint
-
- ColumnAggregationEndpointNullResponse - Class in org.apache.hadoop.hbase.coprocessor
-
Test coprocessor endpoint that always returns null
for requests to the last region
in the table.
- ColumnAggregationEndpointNullResponse() - Constructor for class org.apache.hadoop.hbase.coprocessor.ColumnAggregationEndpointNullResponse
-
- ColumnAggregationEndpointWithErrors - Class in org.apache.hadoop.hbase.coprocessor
-
Test coprocessor endpoint that always throws a
DoNotRetryIOException
for requests on
the last region in the table.
- ColumnAggregationEndpointWithErrors() - Constructor for class org.apache.hadoop.hbase.coprocessor.ColumnAggregationEndpointWithErrors
-
- ColumnAggregationProtos - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationProtos.ColumnAggregationService - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf service ColumnAggregationService
- ColumnAggregationProtos.ColumnAggregationService.BlockingInterface - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationProtos.ColumnAggregationService.Interface - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationProtos.ColumnAggregationService.Stub - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationProtos.SumRequest - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type SumRequest
- ColumnAggregationProtos.SumRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type SumRequest
- ColumnAggregationProtos.SumRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationProtos.SumResponse - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type SumResponse
- ColumnAggregationProtos.SumResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type SumResponse
- ColumnAggregationProtos.SumResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationService() - Constructor for class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationProtos.ColumnAggregationService
-
- ColumnAggregationServiceNullResponse() - Constructor for class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithNullResponseProtos.ColumnAggregationServiceNullResponse
-
- ColumnAggregationServiceWithErrors() - Constructor for class org.apache.hadoop.hbase.coprocessor.protobuf.generated.ColumnAggregationWithErrorsProtos.ColumnAggregationServiceWithErrors
-
- ColumnAggregationWithErrorsProtos - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationWithErrorsProtos.ColumnAggregationServiceWithErrors - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf service ColumnAggregationServiceWithErrors
- ColumnAggregationWithErrorsProtos.ColumnAggregationServiceWithErrors.BlockingInterface - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationWithErrorsProtos.ColumnAggregationServiceWithErrors.Interface - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationWithErrorsProtos.ColumnAggregationServiceWithErrors.Stub - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationWithErrorsProtos.SumRequest - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type SumRequest
- ColumnAggregationWithErrorsProtos.SumRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type SumRequest
- ColumnAggregationWithErrorsProtos.SumRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationWithErrorsProtos.SumResponse - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type SumResponse
- ColumnAggregationWithErrorsProtos.SumResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type SumResponse
- ColumnAggregationWithErrorsProtos.SumResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationWithNullResponseProtos - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationWithNullResponseProtos.ColumnAggregationServiceNullResponse - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf service ColumnAggregationServiceNullResponse
- ColumnAggregationWithNullResponseProtos.ColumnAggregationServiceNullResponse.BlockingInterface - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationWithNullResponseProtos.ColumnAggregationServiceNullResponse.Interface - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationWithNullResponseProtos.ColumnAggregationServiceNullResponse.Stub - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationWithNullResponseProtos.SumRequest - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type SumRequest
- ColumnAggregationWithNullResponseProtos.SumRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type SumRequest
- ColumnAggregationWithNullResponseProtos.SumRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- ColumnAggregationWithNullResponseProtos.SumResponse - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type SumResponse
- ColumnAggregationWithNullResponseProtos.SumResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type SumResponse
- ColumnAggregationWithNullResponseProtos.SumResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- 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.chaos.factories.MonkeyFactory
-
- 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 Message,Q extends Message,R extends 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.codec.prefixtree.column.TestColumnBuilder
-
fields
- COLUMNS - Static variable in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
- COLUMNS - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- columns - Variable in class org.apache.hadoop.hbase.mapred.GroupingTableMap
-
- columns - Variable in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
-
The grouping columns.
- columns - Static variable in class org.apache.hadoop.hbase.mapreduce.TestTableMapReduceBase
-
- columns - Variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- COLUMNS - Static variable in class org.apache.hadoop.hbase.TestSerialization
-
- 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
-
- columnSorter - Variable in class org.apache.hadoop.hbase.codec.prefixtree.column.TestColumnBuilder
-
- 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
- commands - Variable in class org.apache.hadoop.hbase.rest.PerformanceEvaluation
-
- commit() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils.SnapshotMock.SnapshotBuilder
-
- 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
-
- COMMON_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedListWithVisibility
-
- 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(CompactionContext, Store, CompactionThroughputController) - Method in class org.apache.hadoop.hbase.coprocessor.TestRegionObserverScannerOpenHook.CompactionCompletionNotifyingRegion
-
- compact(boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Compact all regions in the mini hbase cluster
- compact(TableName, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Compact all of a table's reagion in the mini hbase cluster
- compact(boolean) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Call flushCache on all regions on all participating regionservers.
- compact(TableName, boolean) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Call flushCache on all regions of the specified table.
- compact(CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionContext
-
Runs the compaction based on current selection.
- compact(CompactionRequest, CompactionThroughputController) - 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, int, long, byte[], byte[], byte[], byte[], CompactionThroughputController) - 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, CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Compact the StoreFiles.
- 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
-
- compact(CompactionThroughputController) - Method in class org.apache.hadoop.hbase.regionserver.TestCompaction.BlockingStoreMockMaker.BlockingCompactionContext
-
- compact(CompactionContext, Store, CompactionThroughputController) - Method in class org.apache.hadoop.hbase.TestIOFencing.CompactionBlockerRegion
-
- compact(ByteBuffer, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- compact(ByteBuffer, <any>) - 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() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.compact
-
- compact(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- compact_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- compact_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- compact_args(Hbase.compact_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
Performs a deep copy on other.
- compact_call(ByteBuffer, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.compact_call
-
- COMPACT_RANDOM_REGION_RATIO - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- compact_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- compact_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- compact_result(Hbase.compact_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
Performs a deep copy on other.
- COMPACT_TABLE_ACTION_RATIO - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- COMPACT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type
-
COMPACT = 6;
- compactAndBlockUntilDone(Admin, HRegionServer, byte[]) - Static method in class org.apache.hadoop.hbase.regionserver.TestEndToEndSplitTransaction
-
- 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
-
- CompactionBlockerRegion(Path, WAL, FileSystem, Configuration, HRegionInfo, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.TestIOFencing.CompactionBlockerRegion
-
- CompactionCompletionNotifyingRegion(Path, WAL, FileSystem, Configuration, HRegionInfo, HTableDescriptor, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.coprocessor.TestRegionObserverScannerOpenHook.CompactionCompletionNotifyingRegion
-
- 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.
- CompactRandomRegionOfTableAction - Class in org.apache.hadoop.hbase.chaos.actions
-
Region that queues a compaction of a random region from the table.
- CompactRandomRegionOfTableAction(TableName, float) - Constructor for class org.apache.hadoop.hbase.chaos.actions.CompactRandomRegionOfTableAction
-
- CompactRandomRegionOfTableAction(int, TableName, float) - Constructor for class org.apache.hadoop.hbase.chaos.actions.CompactRandomRegionOfTableAction
-
- 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(com.google.protobuf.RpcController, AdminProtos.CompactRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.BlockingInterface
-
- compactRegion(com.google.protobuf.RpcController, AdminProtos.CompactRegionRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
rpc CompactRegion(.CompactRegionRequest) returns (.CompactRegionResponse);
- compactRegion(com.google.protobuf.RpcController, AdminProtos.CompactRegionRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService.Interface
-
rpc CompactRegion(.CompactRegionRequest) returns (.CompactRegionResponse);
- compactRegion(com.google.protobuf.RpcController, AdminProtos.CompactRegionRequest, <any>) - 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
- CompactTableAction - Class in org.apache.hadoop.hbase.chaos.actions
-
Action that queues a table compaction.
- CompactTableAction(TableName, float) - Constructor for class org.apache.hadoop.hbase.chaos.actions.CompactTableAction
-
- CompactTableAction(int, TableName, float) - Constructor for class org.apache.hadoop.hbase.chaos.actions.CompactTableAction
-
- 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() - Constructor for class org.apache.hadoop.hbase.io.ImmutableBytesWritable.Comparator
-
constructor
- 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
-
- Comparators() - Constructor for class org.apache.hadoop.hbase.regionserver.StoreFile.Comparators
-
- 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(WritableComparable, WritableComparable) - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.CompositeKeyComparator
-
- compare(WritableComparable, WritableComparable) - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.NaturalKeyGroupingComparator
-
- 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(byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.comparator.ByteArrayComparator
-
- 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
-
- compareArchiveToOriginal(FileStatus[], FileStatus[], FileSystem, boolean) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveTestingUtil
-
- 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
-
- 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(IntegrationTestBulkLoad.LinkChain) - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.LinkChain
-
- compareTo(IntegrationTestBulkLoad.LinkKey) - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.LinkKey
-
- 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(PerformanceEvaluation.RunResult) - Method in class org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
-
- 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 class 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 class org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- compareTo(IOError) - Method in class 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 class org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- compareTo(TIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- compareTo(TIOError) - Method in class 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.
- CompatibilityLatch() - Constructor for class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
-
- 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.codec.prefixtree.row.TestRowEncoder
-
- 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.
- completeCompaction(Collection<StoreFile>, boolean) - Method in class org.apache.hadoop.hbase.TestIOFencing.BlockCompactionsInCompletionHStore
-
- completeCompaction(Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.TestIOFencing.BlockCompactionsInCompletionHStore
-
- 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
-
- CompletedSnaphotDirectoriesFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils.CompletedSnaphotDirectoriesFilter
-
- 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
- completeSplitTransaction(RegionServerServices, Region, Region, SplitTransactionCoordination.SplitTransactionDetails, Region) - Method in class org.apache.hadoop.hbase.regionserver.TestSplitTransactionOnCluster.MockedSplitTransactionCoordination
-
- 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
-
- COMPOSITE_ACTION3_PERIOD - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- CompositeKeyComparator() - Constructor for class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.CompositeKeyComparator
-
- CompositeSequentialPolicy - Class in org.apache.hadoop.hbase.chaos.policies
-
A policy that runs multiple other policies one after the other
- CompositeSequentialPolicy(Policy...) - Constructor for class org.apache.hadoop.hbase.chaos.policies.CompositeSequentialPolicy
-
- 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.
- compressAlgo - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- 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 - Static variable in class org.apache.hadoop.hbase.regionserver.TestHRegionServerBulkLoad
-
- compression - Variable in class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec
-
- COMPRESSION - Static variable in class org.apache.hadoop.hbase.rest.model.TestColumnSchemaModel
-
- compression - Variable in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- compression - Variable in class org.apache.hadoop.hbase.util.TestMiniClusterLoadSequential
-
- Compression.Algorithm - Enum in org.apache.hadoop.hbase.io.compress
-
Compression algorithms.
- COMPRESSION_ALGORITHMS - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Compression algorithms to use in testing
- COMPRESSION_ALGORITHMS_PARAMETERIZED - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Compression algorithms to use in parameterized JUnit 4 tests
- 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
-
- compressionAlgorithms() - Static method in class org.apache.hadoop.hbase.io.hfile.TestHFileBlockIndex
-
- 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.
- computePlanForTable(TableName) - Method in interface org.apache.hadoop.hbase.master.normalizer.RegionNormalizer
-
Computes next optimal normalization plan.
- computePlanForTable(TableName) - Method in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer
-
Computes next most "urgent" normalization action on the table.
- 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
-
- 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(<any>) - 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.
- concurrentReads(Runnable) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluationCommons
-
- 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.HBaseCluster
-
- conf - Variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
- conf - Variable in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
- 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.MapFilePerformanceEvaluation
-
Deprecated.
- 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.TestCompaction
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.TestDefaultCompactSelection
-
- CONF - Static variable in class org.apache.hadoop.hbase.regionserver.TestFailedAppendAndSync
-
- CONF - Static variable in class org.apache.hadoop.hbase.regionserver.TestHRegion
-
- CONF - Static variable in class org.apache.hadoop.hbase.regionserver.TestHRegionReplayEvents
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.TestMajorCompaction
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.TestMinorCompaction
-
- 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.TestCustomWALCellCodec.CustomWALCellCodec
-
- conf - Static variable in class org.apache.hadoop.hbase.regionserver.wal.TestFSHLog
-
- conf - Variable in class org.apache.hadoop.hbase.regionserver.wal.WriterBase
-
- conf - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
- conf - Static variable in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- conf - Static variable in class org.apache.hadoop.hbase.security.visibility.TestDefaultScanLabelGeneratorStack
-
- conf - Static variable in class org.apache.hadoop.hbase.security.visibility.TestEnforcingScanLabelGenerator
-
- conf - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabels
-
- conf - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsReplication
-
- conf - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsWithDeletes
-
- conf - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsWithSLGStack
-
- conf - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLablesWithGroups
-
- conf - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityWithCheckAuths
-
- conf - Variable in class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.LoadMapper
-
- 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.util.hbck.OfflineMetaRebuildTestCore
-
- conf - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
- conf - Variable in class org.apache.hadoop.hbase.util.TestMiniClusterLoadSequential
-
- conf - Static variable in class org.apache.hadoop.hbase.wal.TestBoundedRegionGroupingProvider
-
- conf - Static variable in class org.apache.hadoop.hbase.wal.TestDefaultWALProvider
-
- conf - Static variable in class org.apache.hadoop.hbase.wal.TestWALFactory
-
- conf - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- conf1 - Static variable in class org.apache.hadoop.hbase.replication.TestReplicationBase
-
- conf1 - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsReplication
-
- conf2 - Static variable in class org.apache.hadoop.hbase.replication.TestReplicationBase
-
- 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
-
- CONF_WITH_LOCALFS - Static variable in class org.apache.hadoop.hbase.replication.TestReplicationBase
-
- CONFIDENTIAL - Static variable in class org.apache.hadoop.hbase.security.visibility.TestDefaultScanLabelGeneratorStack
-
- CONFIDENTIAL - Static variable in class org.apache.hadoop.hbase.security.visibility.TestEnforcingScanLabelGenerator
-
- CONFIDENTIAL - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabels
-
- CONFIDENTIAL - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsReplication
-
- CONFIDENTIAL - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsWithSLGStack
-
- CONFIDENTIAL - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLablesWithGroups
-
- 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
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat.ExampleDeprecatedTIF
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat.ExampleJobConfigurableTIF
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat.ExampleVerifier
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapreduce.TestTableInputFormat.ExampleDeprecatedTIF
-
- configure(JobConf) - Method in class org.apache.hadoop.hbase.mapreduce.TestTableInputFormat.ExampleJobConfigurableTIF
-
- 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.
- configureSuperuser(Configuration) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- ConfigUtil - Class in org.apache.hadoop.hbase.util
-
Some configuration related utilities
- ConfigUtil() - Constructor for class org.apache.hadoop.hbase.util.ConfigUtil
-
- confirmEmptySnapshotValid(HBaseProtos.SnapshotDescription, TableName, byte[], Path, Admin, FileSystem) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
Confirm that the snapshot has no references files but only metadata.
- 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
-
- confirmSnapshotValid(HBaseProtos.SnapshotDescription, TableName, byte[], Path, Admin, FileSystem) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
Confirm that the snapshot contains references to all the files that should
be in the snapshot.
- confirmSnapshotValid(HBaseProtos.SnapshotDescription, TableName, List<byte[]>, List<byte[]>, Path, Admin, FileSystem) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
Confirm that the snapshot contains references to all the files that should
be in the snapshot.
- 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
-
- 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.IntegrationTestDDLMasterFailover
-
- Connection(SocketChannel, long) - Constructor for class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- connection - Variable in class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.LoadMapper
-
- connection - Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- connection - Variable in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRebuildTestCore
-
- connection - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
- 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
-
- 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
-
- ConstantDelayQueue<E> - Class in org.apache.hadoop.hbase.util
-
A blocking queue implementation for adding a constant delay.
- ConstantDelayQueue(TimeUnit, long) - Constructor for class org.apache.hadoop.hbase.util.ConstantDelayQueue
-
- 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.
- constructedBlockSize - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.TestBucketCache
-
- constructedBlockSizes - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.TestBucketCache
-
- 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.ConstantDelayQueue
-
- 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.ConstantDelayQueue
-
- 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 - Variable in class org.apache.hadoop.hbase.chaos.actions.Action
-
- context - Variable in class org.apache.hadoop.hbase.chaos.policies.Policy
-
- Context - Class in org.apache.hadoop.hbase.io.crypto
-
Crypto context.
- context - Variable in class org.apache.hadoop.hbase.regionserver.TestBulkLoad
-
- context - Variable in class org.apache.hadoop.hbase.regionserver.wal.TestCustomWALCellCodec.CustomWALCellCodec
-
- Context(Configuration, FileSystem, ReplicationPeerConfig, String, UUID, ReplicationPeer, MetricsSource, TableDescriptors) - Constructor for class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
-
- CONTEXT - Static variable in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
-
- context - Variable in class org.apache.hadoop.hbase.rest.model.TestModelBase
-
- context - Static variable in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- 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
- convertToList(Map<ServerName, List<HRegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerTestBase
-
- convertToNamespace(String) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- 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.
- CoprocessorCounter() - Constructor for class org.apache.hadoop.hbase.replication.TestMasterReplication.CoprocessorCounter
-
- 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
-
- 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
- CoprocessorII() - Constructor for class org.apache.hadoop.hbase.coprocessor.TestCoprocessorInterface.CoprocessorII
-
- CoprocessorImpl() - Constructor for class org.apache.hadoop.hbase.coprocessor.TestCoprocessorInterface.CoprocessorImpl
-
- CoprocessorRpcChannel - Class in org.apache.hadoop.hbase.ipc
-
Base class which provides clients with an RPC connection to
call coprocessor endpoint com.google.protobuf.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 com.google.protobuf.RpcChannel
instance connected to the active
master.
- coprocessorService(ServerName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Creates and returns a com.google.protobuf.RpcChannel
instance
connected to the passed region server.
- coprocessorService() - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates and returns a com.google.protobuf.RpcChannel
instance
connected to the active master.
- coprocessorService(ServerName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Creates and returns a com.google.protobuf.RpcChannel
instance
connected to the passed region server.
- coprocessorService(byte[]) - Method in class org.apache.hadoop.hbase.client.HTable
-
Creates and returns a com.google.protobuf.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
com.google.protobuf.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
com.google.protobuf.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
com.google.protobuf.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 com.google.protobuf.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
com.google.protobuf.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
com.google.protobuf.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
com.google.protobuf.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
-
- COPYRIGHT - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabels
-
- COPYRIGHT - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsReplication
-
- 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
-
- corruptSnapshot(HBaseTestingUtility, String) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
Corrupt the specified snapshot by deleting some files.
- count(com.google.protobuf.RpcController, PingProtos.CountRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService.BlockingInterface
-
- count(com.google.protobuf.RpcController, PingProtos.CountRequest, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService
-
rpc count(.CountRequest) returns (.CountResponse);
- count(com.google.protobuf.RpcController, PingProtos.CountRequest, <any>) - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService.Interface
-
rpc count(.CountRequest) returns (.CountResponse);
- count(com.google.protobuf.RpcController, PingProtos.CountRequest, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.PingService.Stub
-
- count(RpcController, PingProtos.CountRequest, <any>) - Method in class org.apache.hadoop.hbase.regionserver.TestServerCustomProtocol.PingHandler
-
- count(RpcController, PingProtos.CountRequest, <any>) - Method in class org.apache.hadoop.hbase.security.access.TestAccessController.PingCoprocessor
-
- COUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.ExampleProtos.CountResponse
-
- COUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.CountResponse
-
- COUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountResponse
-
- 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
-
- COUNTER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.IncCounterProcessorRequest
-
- CountingChore(String, int) - Constructor for class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.CountingChore
-
- CountingChore(String, Stoppable, int) - Constructor for class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.CountingChore
-
- CountingChore(String, Stoppable, int, boolean) - Constructor for class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.CountingChore
-
- CountingRpcController(PayloadCarryingRpcController) - Constructor for class org.apache.hadoop.hbase.client.TestRpcControllerFactory.CountingRpcController
-
- 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
-
- countRows(Table) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Return the number of rows in the given table.
- countRows(Table, byte[]...) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- countRows(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Return the number of rows in the given table.
- countServedRegions() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Counts the total numbers of regions being served by the currently online
region servers by asking each how many regions they have.
- countStoreFiles() - Method in class org.apache.hadoop.hbase.TestIOFencing.CompactionBlockerRegion
-
- 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
-
- CPMasterObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.TestMasterObserver.CPMasterObserver
-
- CPRegionServerObserver() - Constructor for class org.apache.hadoop.hbase.coprocessor.TestRegionServerObserver.CPRegionServerObserver
-
- CPRegionServerObserver() - Constructor for class org.apache.hadoop.hbase.namespace.TestNamespaceAuditor.CPRegionServerObserver
-
- cq - Variable in class org.apache.hadoop.hbase.regionserver.TestHRegionReplayEvents
-
- 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 - Variable in class org.apache.hadoop.hbase.IntegrationTestDDLMasterFailover
-
- 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
-
- createAndFillTable(TableName) - Static method in class org.apache.hadoop.hbase.mapred.TestTableMapReduceUtil
-
- createAndForceNodeToOpenedState(HBaseTestingUtility, Region, ServerName) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Creates a znode with OPENED state.
- createAndForceNodeToOpenedState(HBaseTestingUtility, HRegion, ServerName) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Creates a znode with OPENED state.
- 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.
- createAndStartTestServer() - Static method in class org.apache.hadoop.hbase.http.HttpServerFunctionalTest
-
Create and start a server with the test webapp
- 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.
- CreateAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateAsyncCallback
-
- 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.client.TestClientTimeouts.RandomTimeoutRpcClient
-
- 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
- createClientSSLConfig(String, String, String, String) - Static method in class org.apache.hadoop.hbase.http.ssl.KeyStoreTestUtil
-
Creates SSL configuration for a client.
- 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
-
- createClusterConf(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Generates a Configuration
instance by applying the ZooKeeper cluster key
to the base Configuration.
- createClusterConf(Configuration, String, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
Generates a Configuration
instance by applying property overrides prefixed by
a cluster profile key to the base Configuration.
- 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
-
- createComponents(Configuration, Store, KeyValue.KVComparator) - Method in class org.apache.hadoop.hbase.regionserver.TestStore.DummyStoreEngine
-
- 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
- createDistributedHBaseCluster() - Method in class org.apache.hadoop.hbase.IntegrationTestingUtility
-
- createDoubleTest() - Method in class org.apache.hadoop.hbase.TestNamespace
-
- 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
-
- createFilterFromArguments(ArrayList<byte[]>) - Static method in class org.apache.hadoop.hbase.rest.TestTableScan.CustomFilter
-
- 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.
- createGet(long) - Method in class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader.TimeBoundedMultiThreadedReaderThread
-
- createGet(long) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
-
- 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
-
- createHFile(FileSystem, Path, byte[], byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.regionserver.TestHRegionServerBulkLoad
-
Create an HFile with the given number of rows with a specified value.
- createHFile(Configuration, FileSystem, Path, byte[], byte[], byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.HFileTestUtil
-
Create an HFile with the given number of rows between a given
start key and end key @ family:qualifier.
- createHFile(Configuration, FileSystem, Path, byte[], byte[], byte[], byte[], int, boolean) - Static method in class org.apache.hadoop.hbase.util.HFileTestUtil
-
Create an HFile with the given number of rows between a given
start key and end key @ family:qualifier.
- 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
- createHFileWithTags(Configuration, FileSystem, Path, byte[], byte[], byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.util.HFileTestUtil
-
Create an HFile with the given number of rows between a given
start key and end key @ family:qualifier.
- createHostAndPortStr(String, int) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- createHRegion(HRegionInfo, Path, Configuration, HTableDescriptor) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create an HRegion.
- 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.
- createHTD(TableName, String...) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureTestingUtility
-
- createHtd(String) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils.SnapshotMock
-
- createIdentifier() - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- createInetSocketAddressFromHostAndPortStr(String) - Static method in class org.apache.hadoop.hbase.util.Addressing
-
- createJob(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.MapreduceTestingShim
-
- createJobContext(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.MapreduceTestingShim
-
- 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).
- createKeyStore(String, String, String, Key, Certificate) - Static method in class org.apache.hadoop.hbase.http.ssl.KeyStoreTestUtil
-
- createKeyStore(String, String, String, String, Key, Certificate) - Static method in class org.apache.hadoop.hbase.http.ssl.KeyStoreTestUtil
-
Creates a keystore with a single key and saves it to a file.
- 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.
- createList(T...) - Static method in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsWithDeletes
-
- createLocalHRegion(HTableDescriptor, byte[], byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create an HRegion that writes to the local tmp dirs
- createLocalHRegion(HRegionInfo, HTableDescriptor) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create an HRegion that writes to the local tmp dirs
- createLocalHRegion(HRegionInfo, HTableDescriptor, WAL) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create an HRegion that writes to the local tmp dirs with specified wal
- createLocalHRegion(byte[], byte[], byte[], String, Configuration, boolean, Durability, WAL, byte[]...) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- createLocalHTU() - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create an HBaseTestingUtility where all tmp files are written to the local test data dir.
- createLocalHTU(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create an HBaseTestingUtility where all tmp files are written to the local test data dir.
- 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
- createMetaRegion() - Method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
- createMockRegionServerService() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a stubbed out RegionServerService, mainly for getting FS.
- createMockRegionServerService(RpcServerInterface) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a stubbed out RegionServerService, mainly for getting FS.
- createMockRegionServerService(ServerName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a stubbed out RegionServerService, mainly for getting FS.
- createMultiRegionsInMeta(Configuration, HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create rows in hbase:meta for regions of the specified table with the specified
start keys.
- createMultiRegionsWithWritableSerialization(Configuration, byte[], int) - Method in class org.apache.hadoop.hbase.TestMetaMigrationConvertingToPB
-
Deprecated.
Inserts multiple regions into hbase:meta using Writable serialization instead of PB
- createMultiRegionsWithWritableSerialization(Configuration, byte[], byte[][]) - Method in class org.apache.hadoop.hbase.TestMetaMigrationConvertingToPB
-
Deprecated.
- createMultiRegionsWithWritableSerialization(Configuration, TableName, byte[][]) - Method in class org.apache.hadoop.hbase.TestMetaMigrationConvertingToPB
-
Deprecated.
Inserts multiple regions into hbase:meta using Writable serialization instead of PB
- createMultiRegionTable(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table with multiple regions.
- createMultiRegionTable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table with multiple regions.
- createMultiRegionTable(TableName, byte[][], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table with multiple regions.
- createMultiRegionTable(TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table with multiple regions.
- 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(com.google.protobuf.RpcController, MasterProtos.CreateNamespaceRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- createNamespace(com.google.protobuf.RpcController, MasterProtos.CreateNamespaceRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc CreateNamespace(.CreateNamespaceRequest) returns (.CreateNamespaceResponse);
- createNamespace(com.google.protobuf.RpcController, MasterProtos.CreateNamespaceRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc CreateNamespace(.CreateNamespaceRequest) returns (.CreateNamespaceResponse);
- createNamespace(com.google.protobuf.RpcController, MasterProtos.CreateNamespaceRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- createNamespace(HBaseTestingUtility, NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- createNewHRegion(HTableDescriptor, byte[], byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
You must call close on the returned region and then close on the log file
it created.
- createNewHRegion(HTableDescriptor, byte[], byte[], Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
- 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.
- createObject(K) - Method in interface org.apache.hadoop.hbase.util.WeakObjectPool.ObjectFactory
-
Creates a new shared object associated with the given key
,
identified by the equals
method.
- 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
-
- createPreemptiveInterceptor(Configuration) - Static method in class org.apache.hadoop.hbase.client.TestFastFailWithoutTestUtil
-
- createPreSplitLoadTestTable(Configuration, TableName, byte[], Compression.Algorithm, DataBlockEncoding) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableName, byte[], Compression.Algorithm, DataBlockEncoding, int, int, Durability) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, TableName, byte[][], Compression.Algorithm, DataBlockEncoding, int, int, Durability) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, HTableDescriptor, HColumnDescriptor) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, HTableDescriptor, HColumnDescriptor, int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(Configuration, HTableDescriptor, HColumnDescriptor[], int) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Creates a pre-split table for load testing.
- createPreSplitLoadTestTable(HTableDescriptor, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.util.TestMiniClusterLoadSequential
-
- createProcedureInfo(Procedure) - 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
-
- CreateRandomStoreFile - Class in org.apache.hadoop.hbase.regionserver
-
Creates an HFile with random key/value pairs.
- CreateRandomStoreFile() - Constructor for class org.apache.hadoop.hbase.regionserver.CreateRandomStoreFile
-
- createRandomTable(String, Collection<String>, int, int, int, int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Creates a random table with the given parameters
- 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.
- createReaderThread(int) - Method in class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader
-
- createReaderThread(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.HLogInputFormat
-
Deprecated.
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.ITBulkLoadInputFormat
-
- 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.NMapInputFormat
-
- 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
-
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.rest.PerformanceEvaluation.PeInputFormat
-
- 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, Table, byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRebuildTestCore
-
- 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.
- createRegionAndWAL(HRegionInfo, Path, Configuration, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a region with it's own WAL.
- createRegionAndWAL(HRegionInfo, Path, Configuration, HTableDescriptor, boolean) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a region with it's own WAL.
- 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.
- createRegionServerStatusStub() - Method in class org.apache.hadoop.hbase.regionserver.TestRegionServerReportForDuty.MyRegionServer
-
- 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
-
- createRemoveTest() - Method in class org.apache.hadoop.hbase.TestNamespace
-
- CreateRescanAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.CreateRescanAsyncCallback
-
- createRootDir(boolean) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Creates an hbase rootdir in user home directory.
- createRootDir() - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- createRpcChannel(ServerName, User, int) - Method in class org.apache.hadoop.hbase.ipc.AsyncRpcClient
-
Creates a "channel" that can be used by a protobuf service.
- createRpcClient(Configuration) - Method in class org.apache.hadoop.hbase.ipc.AbstractTestIPC
-
- createRpcClient(Configuration) - Method in class org.apache.hadoop.hbase.ipc.TestAsyncIPC
-
- createRpcClient(Configuration) - Method in class org.apache.hadoop.hbase.ipc.TestIPC
-
- createRpcClientNoCodec(Configuration) - Method in class org.apache.hadoop.hbase.ipc.AbstractTestIPC
-
- createRpcClientNoCodec(Configuration) - Method in class org.apache.hadoop.hbase.ipc.TestAsyncIPC
-
- createRpcClientNoCodec(Configuration) - Method in class org.apache.hadoop.hbase.ipc.TestIPC
-
- createRpcClientRTEDuringConnectionSetup(Configuration) - Method in class org.apache.hadoop.hbase.ipc.AbstractTestIPC
-
- createRpcClientRTEDuringConnectionSetup(Configuration) - Method in class org.apache.hadoop.hbase.ipc.TestAsyncIPC
-
- createRpcClientRTEDuringConnectionSetup(Configuration) - Method in class org.apache.hadoop.hbase.ipc.TestIPC
-
- 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(String, int) - Static method in class org.apache.hadoop.hbase.http.HttpServerFunctionalTest
-
Create an HttpServer instance on the given address for the given webapp
- createServer(String) - Static method in class org.apache.hadoop.hbase.http.HttpServerFunctionalTest
-
Create an HttpServer instance for the given webapp
- createServer(String, Configuration) - Static method in class org.apache.hadoop.hbase.http.HttpServerFunctionalTest
-
Create an HttpServer instance for the given webapp
- createServer(String, Configuration, AccessControlList) - Static method in class org.apache.hadoop.hbase.http.HttpServerFunctionalTest
-
- createServer(String, Configuration, String[]) - Static method in class org.apache.hadoop.hbase.http.HttpServerFunctionalTest
-
Create an HttpServer instance for the given webapp
- 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
-
- createServerSSLConfig(String, String, String, String) - Static method in class org.apache.hadoop.hbase.http.ssl.KeyStoreTestUtil
-
Creates SSL configuration for a server.
- 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.
- createShortCircuitHConnection(Connection, ServerName, AdminProtos.AdminService.BlockingInterface, ClientProtos.ClientService.BlockingInterface) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Adapt a HConnection so that it can bypass the RPC layer (serialization,
deserialization, networking, etc..) -- i.e.
- 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
-
- createSnapshotAndValidate(Admin, TableName, String, String, Path, FileSystem, boolean) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
Take a snapshot of the specified table and verify that the given family is
not empty.
- createSnapshotAndValidate(Admin, TableName, List<byte[]>, List<byte[]>, String, Path, FileSystem, boolean) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
Take a snapshot of the specified table and verify the given families.
- createSnapshotV1(String, String) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils.SnapshotMock
-
- createSnapshotV2(String, String) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils.SnapshotMock
-
- createStatus(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- createStore(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility
-
- createStoreMock(String) - Method in class org.apache.hadoop.hbase.regionserver.StatefulStoreMockMaker
-
- createStoreMock(String) - Method in class org.apache.hadoop.hbase.regionserver.TestCompaction.BlockingStoreMockMaker
-
- createStoreMock(int, String) - Method in class org.apache.hadoop.hbase.regionserver.TestCompaction.BlockingStoreMockMaker
-
- createSubDir(String, Path, String) - Method in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
- 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.
- createSubmittableJob(String[]) - Method in class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify.WALSearcher
-
- 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(String, String) - Static method in class org.apache.hadoop.hbase.filter.FilterTestingCluster
-
- createTable(TableName, String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(byte[], byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(TableName, String[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(TableName, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(byte[], byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(TableName, byte[][], byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(byte[], byte[][], int, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- createTable(String, byte[][], int, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- createTable(TableName, byte[][], int, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- createTable(HTableDescriptor, byte[][], Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(HTableDescriptor, byte[][], byte[][], Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(TableName, byte[][], Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(TableName, byte[][], byte[][], Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(byte[], byte[][], Configuration) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(TableName, byte[][], Configuration, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(byte[], byte[][], Configuration, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(byte[], byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(TableName, byte[], int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(TableName, byte[][], int, byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(byte[], byte[], byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(TableName, byte[], byte[][]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table.
- createTable(byte[]) - Static method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat
-
Setup a table with two rows and values.
- createTable(byte[], byte[][]) - Static method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat
-
Setup a table with two rows and values per column family.
- createTable(byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.TestTableInputFormat
-
Setup a table with two rows and values.
- createTable(byte[], byte[][]) - Static method in class org.apache.hadoop.hbase.mapreduce.TestTableInputFormat
-
Setup a table with two rows and values per column family.
- createTable(HBaseTestingUtility, HTableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.master.handler.TestEnableTableHandler
-
- createTable(HBaseTestingUtility, HBaseAdmin, HTableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.master.handler.TestEnableTableHandler
-
- createTable(HTableDescriptor, byte[][]) - 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[][]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Create a table using the given table definition.
- createTable(ProcedureExecutor<MasterProcedureEnv>, TableName, byte[][], String...) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureTestingUtility
-
- createTable(com.google.protobuf.RpcController, MasterProtos.CreateTableRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- createTable(com.google.protobuf.RpcController, MasterProtos.CreateTableRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc CreateTable(.CreateTableRequest) returns (.CreateTableResponse);
- createTable(com.google.protobuf.RpcController, MasterProtos.CreateTableRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc CreateTable(.CreateTableRequest) returns (.CreateTableResponse);
- createTable(com.google.protobuf.RpcController, MasterProtos.CreateTableRequest, <any>) - 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(HBaseTestingUtility, TableName, byte[][]) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- createTable(HBaseTestingUtility, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- createTable(HBaseTestingUtility, HTableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- createTable(HBaseTestingUtility, Admin, HTableDescriptor) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- createTable(HBaseTestingUtility, Admin, HTableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- createTable(HBaseTestingUtility, TableName, int, byte[]...) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
- createTable(HBaseTestingUtility, TableName, byte[]...) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
- createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.StripeCompactionsPerformanceEvaluation
-
- createTable(ByteBuffer, List<ColumnDescriptor>, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- createTable(ByteBuffer, List<ColumnDescriptor>, <any>) - 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() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.createTable
-
- createTable(ByteBuffer, List<ColumnDescriptor>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- createTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader.HBaseReaderThread
-
- createTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL.HBaseReaderThreadWithACL
-
- createTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater.HBaseUpdaterThread
-
- createTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL.HBaseUpdaterThreadWithACL
-
- createTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter.HBaseWriterThread
-
- createTable() - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL.HBaseWriterThreadWithACL
-
- createTable(HBaseTestingUtility, HTableDescriptor, byte[][]) - Static method in class org.apache.hadoop.hbase.util.TestHBaseFsck
-
- createTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- createTable_args(ByteBuffer, List<ColumnDescriptor>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- createTable_args(Hbase.createTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
Performs a deep copy on other.
- createTable_call(ByteBuffer, List<ColumnDescriptor>, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.createTable_call
-
- createTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- createTable_result(IOError, IllegalArgument, AlreadyExists) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- createTable_result(Hbase.createTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
Performs a deep copy on other.
- createTableAndSnapshot(HBaseTestingUtility, TableName, String, int) - Static method in class org.apache.hadoop.hbase.client.TestTableSnapshotScanner
-
- createTableAndSnapshot(HBaseTestingUtility, TableName, String, byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatTestBase
-
- createTableAndWriteDataWithLabels(TableName, String...) - Static method in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsWithDeletes
-
- createTableAndWriteDataWithLabels(TableName, long[], String...) - Static method in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsWithDeletes
-
- 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(String) - Method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
Create a table of name name
with COLUMNS
for
families.
- createTableDescriptor(String, int) - Method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
Create a table of name name
with COLUMNS
for
families.
- createTableDescriptor(String, int, int, int, KeepDeletedCells) - Method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
Create a table of name name
with COLUMNS
for
families.
- createTableDescriptor(String, int, int, int, KeepDeletedCells) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table of name name
with COLUMNS
for
families.
- createTableDescriptor(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create a table of name name
with COLUMNS
for
families.
- createTableDescriptor(String) - Method in class org.apache.hadoop.hbase.TestSerialization
-
Create a table of name name
with COLUMNS
for
families.
- createTableDescriptor(String, int) - Method in class org.apache.hadoop.hbase.TestSerialization
-
Create a table of name name
with COLUMNS
for
families.
- 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
-
- createTableInDefaultNamespace() - Method in class org.apache.hadoop.hbase.TestNamespace
-
- createTableInSystemNamespace() - Method in class org.apache.hadoop.hbase.TestNamespace
-
- 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
-
- createTableTest() - Method in class org.apache.hadoop.hbase.TestNamespace
-
- CreateTableThread(HBaseTestingUtility) - Constructor for class org.apache.hadoop.hbase.coprocessor.TestMasterCoprocessorExceptionWithAbort.CreateTableThread
-
- 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.
- createTestBlockStr(Compression.Algorithm, int, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.TestHFileBlock
-
- createTestDir() - Static method in class org.apache.hadoop.hbase.TestClassFinder
-
- createTestRegion(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- createTestServer() - Static method in class org.apache.hadoop.hbase.http.HttpServerFunctionalTest
-
Create but do not start the test webapp server.
- createTestServer(Configuration) - Static method in class org.apache.hadoop.hbase.http.HttpServerFunctionalTest
-
Create but do not start the test webapp server.
- createTestServer(Configuration, AccessControlList) - Static method in class org.apache.hadoop.hbase.http.HttpServerFunctionalTest
-
- createTestServer(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.http.HttpServerFunctionalTest
-
Create but do not start the test webapp server.
- createTestTables(Hbase.Iface) - Static method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
- createTestTaskAttemptContext(J, String) - Method in interface org.apache.hadoop.hbase.HadoopShims
-
Returns a TaskAttemptContext instance created from the given parameters.
- createTestTaskAttemptContext(J, String) - Method in class org.apache.hadoop.hbase.HadoopShimsImpl
-
Returns a TaskAttemptContext instance created from the given parameters.
- createTestV1Block(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.TestHFileBlock
-
- createTestV1Block(Compression.Algorithm) - Method in class org.apache.hadoop.hbase.io.hfile.TestHFileBlockCompatibility
-
- 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
-
- createTimestampRange(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.TestSeekOptimizations
-
- createTopReference(byte[]) - Static method in class org.apache.hadoop.hbase.io.Reference
-
- createTreeSet() - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
-
- createTrustStore(String, String, String, Certificate) - Static method in class org.apache.hadoop.hbase.http.ssl.KeyStoreTestUtil
-
- createTrustStore(String, String, Map<String, T>) - Static method in class org.apache.hadoop.hbase.http.ssl.KeyStoreTestUtil
-
- 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 class org.apache.hadoop.hbase.security.visibility.ExpAsStringVisibilityLabelServiceImpl
-
- 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
-
- createWal(Configuration, Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Create an unmanaged WAL.
- createWalStore(Configuration, FileSystem, Path) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility
-
- 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
-
- createWriteKeysQueue(Configuration) - Method in class org.apache.hadoop.hbase.IntegrationTestRegionReplicaReplication.DelayingMultiThreadedUpdater
-
- createWriteKeysQueue(Configuration) - Method in class org.apache.hadoop.hbase.IntegrationTestRegionReplicaReplication.DelayingMultiThreadedWriter
-
- createWriteKeysQueue(Configuration) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterBase
-
- 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() - Method in class org.apache.hadoop.hbase.regionserver.TestStripeCompactor.StoreFileWritersCapture
-
- 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
-
- createWriterThreads(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriter
-
- createWriterThreads(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedWriterWithACL
-
- 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.MultithreadedTestUtil.TestThread
-
- 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
-
- 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
-
- currentTest - Variable in class org.apache.hadoop.hbase.coprocessor.TestWALObserver
-
- currentTest - Variable in class org.apache.hadoop.hbase.regionserver.wal.TestFSHLog
-
- currentTest - Variable in class org.apache.hadoop.hbase.regionserver.wal.TestProtobufLog
-
- currentTest - Variable in class org.apache.hadoop.hbase.regionserver.wal.TestWALReplay
-
- currentTest - Variable in class org.apache.hadoop.hbase.wal.TestBoundedRegionGroupingProvider
-
- currentTest - Variable in class org.apache.hadoop.hbase.wal.TestDefaultWALProvider
-
- currentTest - Variable in class org.apache.hadoop.hbase.wal.TestWALFactory
-
- currentTest - Variable in class org.apache.hadoop.hbase.wal.TestWALReaderOnSecureWAL
-
- 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
-
- currentTime() - Method in class org.apache.hadoop.hbase.util.TimeOffsetEnvironmentEdge
-
- 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 RPC Controller factory allows frameworks to change the RPC controller.
- CUSTOM_FILTERS - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- CUSTOM_RPC_CLIENT_IMPL_CONF_KEY - Static variable in class org.apache.hadoop.hbase.ipc.RpcClientFactory
-
- CustomFilter(byte[]) - Constructor for class org.apache.hadoop.hbase.rest.TestTableScan.CustomFilter
-
- CustomObserver() - Constructor for class org.apache.hadoop.hbase.namespace.TestNamespaceAuditor.CustomObserver
-
- CustomObserver() - Constructor for class org.apache.hadoop.hbase.regionserver.TestSplitTransaction.CustomObserver
-
- CustomStoreFlusher(Configuration, Store) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.TestWALReplay.CustomStoreFlusher
-
- CustomThreadPoolCoprocessor() - Constructor for class org.apache.hadoop.hbase.coprocessor.TestOpenTableInCoprocessor.CustomThreadPoolCoprocessor
-
- CustomWALCellCodec(Configuration, CompressionContext) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.TestCustomWALCellCodec.CustomWALCellCodec
-