Skip navigation links
Hortonworks Data Platform 3.0.0
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 

I

IdentityTableMap - Class in org.apache.hadoop.hbase.mapred
Pass the given key and record as-is to reduce
IdentityTableMap() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableMap
constructor
IdentityTableMapper - Class in org.apache.hadoop.hbase.mapreduce
Pass the given key and record as-is to the reduce phase.
IdentityTableMapper() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
 
IdentityTableReduce - Class in org.apache.hadoop.hbase.mapred
Write to table each key, record pair
IdentityTableReduce() - Constructor for class org.apache.hadoop.hbase.mapred.IdentityTableReduce
 
IdentityTableReducer - Class in org.apache.hadoop.hbase.mapreduce
Convenience class that simply writes all values (which must be Put or Delete instances) passed to it out to the configured HBase table.
IdentityTableReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.IdentityTableReducer
 
IGNORE_MISSING_FILES - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
IGNORE_UNMATCHED_CF_CONF_KEY - Static variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
 
ignoreConflicts - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
 
ImmutableMemStoreLAB - Class in org.apache.hadoop.hbase.regionserver
A MemStoreLAB implementation which wraps N MemStoreLABs.
ImmutableMemStoreLAB(List<MemStoreLAB>) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
 
ImmutableSegment - Class in org.apache.hadoop.hbase.regionserver
ImmutableSegment is an abstract class that extends the API supported by a Segment, and is not needed for a MutableSegment.
ImmutableSegment(CellComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableSegment
------------------------------------------------------------------------ Empty C-tor to be used only for CompositeImmutableSegment
ImmutableSegment(CellComparator, List<ImmutableSegment>) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableSegment
 
ImmutableSegment(CellSet, CellComparator, MemStoreLAB) - Constructor for class org.apache.hadoop.hbase.regionserver.ImmutableSegment
------------------------------------------------------------------------ C-tor to be used to build the derived classes
implClassName - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
The class name of the runtime implementation, used as prefix for logging/tracing.
Import - Class in org.apache.hadoop.hbase.mapreduce
Import data written by Export.
Import() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import
 
Import.CellImporter - Class in org.apache.hadoop.hbase.mapreduce
A mapper that just writes out KeyValues.
Import.CellReducer - Class in org.apache.hadoop.hbase.mapreduce
 
Import.CellSortImporter - Class in org.apache.hadoop.hbase.mapreduce
 
Import.CellWritableComparable - Class in org.apache.hadoop.hbase.mapreduce
 
Import.CellWritableComparable.CellWritableComparator - Class in org.apache.hadoop.hbase.mapreduce
 
Import.CellWritableComparablePartitioner - Class in org.apache.hadoop.hbase.mapreduce
 
Import.Importer - Class in org.apache.hadoop.hbase.mapreduce
Write table content out to files in hdfs.
Import.KeyValueImporter - Class in org.apache.hadoop.hbase.mapreduce
Deprecated.
Use Import.CellImporter. Will be removed from 3.0 onwards
Import.KeyValueReducer - Class in org.apache.hadoop.hbase.mapreduce
Deprecated.
Use Import.CellReducer. Will be removed from 3.0 onwards
Import.KeyValueSortImporter - Class in org.apache.hadoop.hbase.mapreduce
Deprecated.
Use Import.CellSortImporter. Will be removed from 3.0 onwards
Import.KeyValueWritableComparable - Class in org.apache.hadoop.hbase.mapreduce
 
Import.KeyValueWritableComparable.KeyValueWritableComparator - Class in org.apache.hadoop.hbase.mapreduce
 
Import.KeyValueWritableComparablePartitioner - Class in org.apache.hadoop.hbase.mapreduce
Deprecated.
Use Import.CellWritableComparablePartitioner. Will be removed from 3.0 onwards
IMPORT_FORMAT_VER - Static variable in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
Importer() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.Importer
 
ImportTsv - Class in org.apache.hadoop.hbase.mapreduce
Tool to import data from a TSV file.
ImportTsv() - Constructor for class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
ImportTsv.TsvParser - Class in org.apache.hadoop.hbase.mapreduce
 
ImportTsv.TsvParser.BadTsvLineException - Exception in org.apache.hadoop.hbase.mapreduce
 
IN_MEMORY - Static variable in class org.apache.hadoop.hbase.rest.model.TestColumnSchemaModel
 
IN_MEMORY_FLUSH_THRESHOLD_FACTOR_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
 
INC_BLOCKCACHE_TUNING_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
INC_BLOCKCACHE_TUNING_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
INC_MEMSTORE_TUNING_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
INC_MEMSTORE_TUNING_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
incActiveWorkerCount() - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Increment number of active thrift workers.
incarnation - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
incCall(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Add how long a call took
incCounters(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Add some amount to a counter.
incCounters(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incGauge(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Add some amount to a gauge.
incGauge(String, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incInfoThresholdExceeded(int) - Method in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
Increment the INFO level threshold exceeded count
IncludeAllCompactionQueryMatcher - Class in org.apache.hadoop.hbase.regionserver.querymatcher
A compaction query matcher that always return INCLUDE and drops nothing.
IncludeAllCompactionQueryMatcher(ScanInfo, DeleteTracker, ColumnTracker, long, long, long) - Constructor for class org.apache.hadoop.hbase.regionserver.querymatcher.IncludeAllCompactionQueryMatcher
 
includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatBase
Test if the given region is to be included in the InputSplit while splitting the regions of a table.
includeRegionInSplit(byte[], byte[]) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Test if the given region is to be included in the InputSplit while splitting the regions of a table.
includesTimeRange(TimeRange) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
Check if the range has ANY overlap with TimeRange
includeTimestamp(Cell) - Method in class org.apache.hadoop.hbase.regionserver.TimeRangeTracker
Update the current TimestampRange to include the timestamp from cell.
incMemStoreSize(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
Updates the heap size counter of the segment by the given delta
incMemStoreSize(long, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
 
incMemStoreSize(MemStoreSize) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
 
incMemStoreSize(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
incMethodTime(String, long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Add how long a method took
incNumRowKeysInBatchGet(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Add how many keys were in a batch get.
incNumRowKeysInBatchMutate(int) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Add how many keys were in a batch mutate.
incrAppliedBatches(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
 
incrAppliedHFiles(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
 
incrAppliedOps(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSource
 
incrBatchesShipped(int) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrBytesSkippedInUncleanlyClosedWALs(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrBytesSkippedInUncleanlyClosedWALs(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrCompletedRecoveryQueue() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrCompletedRecoveryQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrCompletedWAL() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrCompletedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incReadFailureCount() - Method in interface org.apache.hadoop.hbase.tool.Canary.Sink
 
incReadFailureCount() - Method in class org.apache.hadoop.hbase.tool.Canary.StdOutSink
 
increaseAboveHeapOccupancyLowWatermarkCounter() - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
Increase the counter for heap occupancy percent above low watermark
increaseAboveHeapOccupancyLowWatermarkCounter() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
Increase the counter for heap occupancy percent above low watermark
increaseTunerDoNothingCounter() - Method in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManager
Increase the counter for tuner neither expanding memstore global size limit nor expanding blockcache max size.
increaseTunerDoNothingCounter() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
Increase the counter for tuner neither expanding memstore global size limit nor expanding blockcache max size.
IncreasingToUpperBoundRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
Split size is the number of regions that are on this server that all are of the same table, cubed, times 2x the region flush size OR the maximum region split size, whichever is smaller.
IncreasingToUpperBoundRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
 
increment(Increment) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
increment(Increment, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
increment(Increment) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
INCREMENT_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
INCREMENT_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsTableLatencies
 
incrementAndGetRetries() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionFailedOpen
 
incrementAppendCount() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Increment the count of wal appends
incrementAppendSize(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Add the append size.
incrementAppendTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Add the time it took to append.
incrementAuthFailedCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
Increment the count of failed ops due to AUTHFAILED Exception.
incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
incrementBadLineCount(int) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
 
incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
incrementCompactionsQueuedCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
incrementConnectionLossCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
Increment the count of failed ops due to a CONNECTIONLOSS Exception.
incrementDataInconsistencyCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
Increment the count of failed ops due to a DATAINCONSISTENCY Exception.
incrementFailedAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementFailedAppendRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number failed append requests.
incrementFailedDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementFailedDeleteRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of failed Delete requests.
incrementFailedGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementFailedGetRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of failed Get requests.
incrementFailedIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementFailedIncrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number failed increment requests.
incrementFailedPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementFailedPutRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of failed Put Requests.
incrementFailedScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementFailedScanRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number failed scan requests.
incrementFlushesQueuedCount() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
incrementInvalidACLCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
Increment the count of failed ops due to INVALIDACL Exception.
incrementLogRollRequested() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
incrementLowReplicationLogRoll() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
incrementNoAuthCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
Increment the count of failed ops due to NOAUTH Exception.
incrementNumOfDeletes() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
 
incrementNumOfPuts() - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
 
incrementNumRegionSizeReportsSent(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
incrementNumRegionSizeReportsSent(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
Updates the metric tracking how many region size reports were sent from this RegionServer to the Master.
incrementOperationCounter() - Method in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
 
incrementOperationCounter() - Method in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
TODO: Remove.
incrementOperationTimeoutCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
Increment the count of failed ops due to an OPERATIONTIMEOUT Exception.
incrementQuotaObserverTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
Sets the execution time of a period of the QuotaObserverChore.
incrementRegionSizeReportingChoreTime(long) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
incrementRegionSizeReportingChoreTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
Updates the metric tracking how much time was spent sending region size reports to the Master by the RegionSizeReportingChore.
incrementRequests(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
 
incrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of requests
incrementResponseBlockSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
 
incrementResponseCellSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
Add on the given amount to the retained cell size.
incrementResponseExceptionSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
 
incrementRuntimeInconsistencyCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
Increment the count of failed ops due to RUNTIMEINCONSISTENCY Exception.
incrementSessionExpiredCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
Increment the count of failed ops due to a SESSIONEXPIRED Exception.
incrementSlowAppendCount() - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Increment the number of appends that were slow
incrementSnapshotFetchTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
Sets the execution time to fetch the mapping of snapshots to originating table.
incrementSnapshotObserverChoreTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
Updates the metric tracking the amount of time taken by the SnapshotQuotaObserverChore which runs periodically.
incrementSnapshotObserverSnapshotComputationTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
Updates the metric tracking the amount of time taken by the SnapshotQuotaObserverChore to compute the size of one snapshot, relative to the files referenced by the originating table.
incrementSnapshotObserverSnapshotFetchTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
Updates the metric tracking the amount of time taken by the SnapshotQuotaObserverChore to fetch all snapshots.
incrementSnapshotObserverTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
Sets the execution time of a period of the SnapshotQuotaObserverChore.
incrementSnapshotSizeComputationTime(long) - Method in class org.apache.hadoop.hbase.master.MetricsMaster
Sets the execution time to compute the size of a single snapshot.
incrementSpaceQuotaFileSystemScannerChoreTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
Updates the metric tracking how much time was spent scanning the filesystem to compute the size of each region hosted by this RegionServer.
incrementSpaceQuotaObserverChoreTime(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
Updates the metric tracking the amount of time taken by the QuotaObserverChore which runs periodically.
incrementSpaceQuotaRefresherChoreTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerQuotaSource
Updates the metric tracking how much time was spent updating the RegionServer with the latest information on space quotas from the hbase:quota table.
incrementSucessfulAppendRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementSucessfulAppendRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of successful append requests.
incrementSucessfulDeleteRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementSucessfulDeleteRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of successful Delete requests.
incrementSucessfulGetRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementSucessfulGetRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of successful Get requests.
incrementSucessfulIncrementRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementSucessfulIncrementRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of successful increment requests.
incrementSucessfulPutRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementSucessfulPutRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of successful Put requests.
incrementSucessfulScanRequests(int) - Method in class org.apache.hadoop.hbase.rest.MetricsREST
 
incrementSucessfulScanRequests(int) - Method in interface org.apache.hadoop.hbase.rest.MetricsRESTSource
Increment the number of successful scan requests.
incrementSyncTime(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
Add the time it took to sync the wal.
incrementSystemErrorCount() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
Increment the count of failed ops due to a SYSTEMERROR Exception.
incrementTotalFailedZKCalls() - Method in interface org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSource
Record the total number of failed ZooKeeper API calls.
incrementValueJson(String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
 
incrementValuePB(String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
 
incrementValueXML(String, String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
 
incrementWrittenBytes(long) - Method in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
 
incRequests(long) - Method in interface org.apache.hadoop.hbase.master.MetricsMasterSource
Increment the number of requests the cluster has seen.
incrHFilesShipped(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrLogEditsFiltered(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrLogEditsFiltered(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Add on the number of log edits filtered
incrLogEditsFiltered() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
The number of log edits filtered out.
incrLogEditsRead() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Increment the number of log edits read by one.
incrLogReadInBytes(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrLogReadInBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
increase the byte number read by source from log file
incrLogReadInEdits(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrMiscInvocations() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
 
incrMiscInvocations() - Method in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
 
incrMiscInvocations() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
 
incrOpsShipped(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrRepeatedFileBytes(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrRepeatedFileBytes(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrRestartedWALReading() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrRestartedWALReading() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrShippedBytes(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrSizeOfHFileRefsQueue(long) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrSizeOfHFileRefsQueue(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrSizeOfLogQueue(int) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrSizeOfLogQueue() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
Increment size of the log queue.
incrSlowAppend() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment the number of slow Appends that have happened.
incrSlowDelete() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment the number of slow Deletes that have happened.
incrSlowGet() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment the number of slow Gets that have happened.
incrSlowIncrement() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment the number of slow Increments that have happened.
incrSlowPut() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment the number of slow Puts that have happened.
incrSplitRequest() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
incrSplitRequest() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment number of a requested splits
incrSplitSuccess() - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServer
 
incrSplitSuccess() - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
Increment number of successful splits
incrUncleanlyClosedWALs() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrUncleanlyClosedWALs() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incrUnknownFileLengthForClosedWAL() - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
 
incrUnknownFileLengthForClosedWAL() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
 
incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
 
incScannerCount() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
Called when opening a scanner on the data of this MemStoreLAB
incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
Called when opening a scanner on the data of this MemStoreLAB
incScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
incSlowCall(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Increment how long a slow call took.
incTimeInQueue(long) - Method in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
Add how long an operation was in the queue.
incWarnThresholdExceeded(int) - Method in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
Increment the WARN level threshold exceeded count
incWriteFailureCount() - Method in interface org.apache.hadoop.hbase.tool.Canary.Sink
 
incWriteFailureCount() - Method in class org.apache.hadoop.hbase.tool.Canary.StdOutSink
 
INDEX_CHUNK_PERCENTAGE_DEFAULT - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
 
INDEX_CHUNK_PERCENTAGE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
 
INDEX_CHUNK_UNUSED_SPACE_PRECENTAGE - Static variable in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
 
INDEX_KEY - Static variable in class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedListWithVisibility
 
indexEntryOffHeapSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
 
indexEntryOffHeapSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
indexEntryOnHeapSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
 
indexEntryOnHeapSize(boolean) - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
 
indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
 
indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
 
indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.CSLMImmutableSegment
 
indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.MutableSegment
 
indexEntrySize() - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
indexSize() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
 
inferBoundaries(SortedMap<byte[], Integer>) - Static method in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
Infers region boundaries for a new table.
INFO_THRESHOLD_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
 
INFO_THRESHOLD_COUNT_KEY - Static variable in interface org.apache.hadoop.hbase.metrics.JvmPauseMonitorSource
 
InfoServer - Class in org.apache.hadoop.hbase.http
Create a Jetty embedded server to answer http requests.
InfoServer(String, String, int, boolean, Configuration) - Constructor for class org.apache.hadoop.hbase.http.InfoServer
Create a status server on the given port.
infoServer - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.Action
 
init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.AddColumnAction
 
init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.DecreaseMaxHFileSizeAction
 
init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.DumpClusterStatusAction
 
init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.RemoveColumnAction
 
init(Action.ActionContext) - Method in class org.apache.hadoop.hbase.chaos.actions.SplitAllRegionOfTableAction
 
init(Policy.PolicyContext) - Method in class org.apache.hadoop.hbase.chaos.policies.CompositeSequentialPolicy
 
init(Policy.PolicyContext) - Method in class org.apache.hadoop.hbase.chaos.policies.DoActionsOncePolicy
 
init(Policy.PolicyContext) - Method in class org.apache.hadoop.hbase.chaos.policies.PeriodicPolicy
 
init(Policy.PolicyContext) - Method in class org.apache.hadoop.hbase.chaos.policies.PeriodicRandomActionPolicy
 
init(Policy.PolicyContext) - Method in class org.apache.hadoop.hbase.chaos.policies.Policy
 
init(Policy.PolicyContext) - Method in class org.apache.hadoop.hbase.chaos.policies.TwoConcurrentActionPolicy
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.ClickjackingPreventionFilter
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
 
init() - Method in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
Initialize this servlet.
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.NoCacheFilter
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.TestGlobalFilter.RecordingFilter
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.TestHttpServer.DummyServletFilter
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.TestPathFilter.RecordingFilter
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.TestServletFilter.ErrorFilter
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.http.TestServletFilter.SimpleFilter
 
init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
 
init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
Does some quick initialization.
init(RpcScheduler.Context) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReader
Build the scanner.
init() - Method in class org.apache.hadoop.hbase.mapred.TableRecordReaderImpl
Build the scanner.
init() - Method in class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
 
init() - Method in interface org.apache.hadoop.hbase.mapreduce.VisibilityExpressionResolver
Giving a chance for the initialization.
init(Map<String, Object>) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
 
init(Map<String, Object>) - Method in interface org.apache.hadoop.hbase.master.cleaner.FileCleanerDelegate
this method is used to pass some instance into subclass
init(Map<String, Object>) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
 
init() - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
Clear out the metrics and re-prepare the source.
init(StoreScanner, AbstractMultiFileWriter.WriterFactory) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
Initializes multi-writer before usage.
init() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
Actually claim the memory for this chunk.
init(FileSystem, Path, Configuration, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
init(FileSystem, Path, Configuration, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
init(FileSystem, Path, Configuration, FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
 
init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
 
init() - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Server, String, UUID, ReplicationEndpoint, WALFileLengthProvider, MetricsSource) - Method in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSource
 
init(ReplicationEndpoint.Context) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
 
init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Server, String, UUID, ReplicationEndpoint, WALFileLengthProvider, MetricsSource) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
Instantiation method used by region servers
init(Configuration, FileSystem, ReplicationSourceManager, ReplicationQueues, ReplicationPeers, Server, String, UUID, ReplicationEndpoint, WALFileLengthProvider, MetricsSource) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
Initializer for the source
init(Connection) - Method in interface org.apache.hadoop.hbase.replication.regionserver.WALEntrySinkFilter
Called after Construction.
init(ReplicationEndpoint.Context) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Initialize the replication endpoint with the given context.
init(FilterConfig) - Method in class org.apache.hadoop.hbase.rest.DummyFilter
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
 
init(FilterConfig) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
 
init() - Method in interface org.apache.hadoop.hbase.test.MetricsAssertHelper
Init helper.
initAdmin() - Method in class org.apache.hadoop.hbase.tool.Canary.Monitor
 
initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
initAfterCompression() - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
Initializes the compression after the shared stuff has been initialized.
initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
Initializes the compression after the shared stuff has been initialized.
initAfterCompression(String) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogReader
 
initAfterHeader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
initAfterHeader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureAsyncProtobufLogWriter
 
initAfterHeader(boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.SecureProtobufLogWriter
 
initCellFilters() - Method in class org.apache.hadoop.hbase.replication.ChainWALEntryFilter
 
initCosts(BaseLoadBalancer.Cluster) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
initCredentials(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
initCredentials(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
 
initCredentialsForCluster(Job, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
initCredentialsForCluster(Job, Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Obtain an authentication token, for the specified cluster, on behalf of the current user and add it to the credentials for the given map reduce job.
initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.FilterInitializer
Initialize a Filter to a FilterContainer.
initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter
 
initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.TestGlobalFilter.RecordingFilter.Initializer
 
initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.TestHttpServer.DummyFilterInitializer
 
initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.TestPathFilter.RecordingFilter.Initializer
 
initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.TestServletFilter.ErrorFilter.Initializer
 
initFilter(FilterContainer, Configuration) - Method in class org.apache.hadoop.hbase.http.TestServletFilter.SimpleFilter.Initializer
 
initialChore() - Method in class org.apache.hadoop.hbase.master.CatalogJanitor
 
initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormat
 
initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Handle subclass specific set up.
initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat.ExampleJobConfigurableTIF
 
initialize(JobConf) - Method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat.ExampleTIF
 
initialize(JobConf, String) - Method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat.ExampleTIF
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.FixedRecordReader
 
initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
 
initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Handle subclass specific set up.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReader
Initializes the reader.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableRecordReaderImpl
Build the scanner.
initialize(TableSnapshotInputFormatImpl.InputSplit, Configuration) - Method in class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.RecordReader
 
initialize(JobContext) - Method in class org.apache.hadoop.hbase.mapreduce.TestTableInputFormat.ExampleTIF
 
initialize() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
initialize() - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
 
initialize() - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Initialize the load balancer.
initialize(MasterServices, MetricsMaster) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
initialize() - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
Initialize the region assignment snapshot by scanning the hbase:meta table
initialize(int, boolean, long, float, float, HeapMemoryManager) - Static method in class org.apache.hadoop.hbase.regionserver.ChunkCreator
Initializes the instance of ChunkCreator
initialize() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Deprecated.
use HRegion.createHRegion() or HRegion.openHRegion()
initialize(Server, FileSystem, Path, Path, WALProvider) - Method in interface org.apache.hadoop.hbase.regionserver.ReplicationService
Initializes the replication service object.
initialize(S) - Method in interface org.apache.hadoop.hbase.regionserver.RowProcessor
Deprecated.
This method should initialize any field(s) of the RowProcessor with a parsing of the passed message bytes (used on the server side).
initialize(Server, FileSystem, Path, Path, WALProvider) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.hadoop.hbase.rest.PerformanceEvaluation.PeInputFormat.PeRecordReader
 
initialize() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
initializeAndGetReadLatencyForTable(String) - Method in class org.apache.hadoop.hbase.tool.Canary.RegionStdOutSink
 
initializeCluster(int) - Method in class org.apache.hadoop.hbase.IntegrationTestingUtility
Initializes the state of the cluster.
initialized - Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
 
initializeMemStoreChunkCreator() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
initializeQueues(int) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
Initializer() - Constructor for class org.apache.hadoop.hbase.http.TestGlobalFilter.RecordingFilter.Initializer
 
Initializer() - Constructor for class org.apache.hadoop.hbase.http.TestPathFilter.RecordingFilter.Initializer
 
Initializer() - Constructor for class org.apache.hadoop.hbase.http.TestServletFilter.ErrorFilter.Initializer
 
Initializer() - Constructor for class org.apache.hadoop.hbase.http.TestServletFilter.SimpleFilter.Initializer
 
initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapred.TableInputFormatBase
Allows subclasses to initialize the table information.
initializeTable(Connection, TableName) - Method in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
Allows subclasses to initialize the table information.
initializeWriteLatency() - Method in class org.apache.hadoop.hbase.tool.Canary.RegionStdOutSink
 
initialServers - Variable in class org.apache.hadoop.hbase.chaos.actions.Action
 
initialSize - Variable in class org.apache.hadoop.hbase.regionserver.IncreasingToUpperBoundRegionSplitPolicy
 
initialStatus - Variable in class org.apache.hadoop.hbase.chaos.actions.Action
 
initJob(String, String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.GroupingTableMap
Use this before submitting a TableMap job.
initJob(String, String, Class<? extends TableMap>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.IdentityTableMap
Use this before submitting a TableMap job.
initJob(String, Scan, String, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.GroupingTableMapper
Use this before submitting a TableMap job.
initJob(String, Scan, Class<? extends TableMapper>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.IdentityTableMapper
Use this before submitting a TableMap job.
initJob(List<Scan>, Job) - Method in class org.apache.hadoop.hbase.mapreduce.MultiTableInputFormatTestBase
 
initJob(List<Scan>, Job) - Method in class org.apache.hadoop.hbase.mapreduce.TestMultiTableInputFormat
 
initJob(List<Scan>, Job) - Method in class org.apache.hadoop.hbase.mapreduce.TestMultiTableSnapshotInputFormat
 
initMultiTableSnapshotMapperJob(Map<String, Collection<Scan>>, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets up the job for reading from one or more multiple table snapshots, with one or more scans per snapshot.
initMultiTableSnapshotMapperJob(Map<String, Collection<Scan>>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets up the job for reading from one or more table snapshots, with one or more scans per snapshot.
initMultiWriter(AbstractMultiFileWriter, InternalScanner, Compactor.FileDetails, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.AbstractMultiOutputCompactor
 
initOutput(FileSystem, Path, boolean, int, short, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
initOutput(FileSystem, Path, boolean, int, short, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
 
initOutput(FileSystem, Path, boolean, int, short, long) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
initReader(FSDataInputStream) - Method in class org.apache.hadoop.hbase.regionserver.wal.ReaderBase
Initializes the log reader with a particular stream (may be null).
initReconfigurable(Configuration) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
initSource() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
A function to instantiate the metrics source.
initSource() - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
This function overrides the initSource in the MetricsBalancer, use MetricsStochasticBalancerSource instead of the MetricsBalancerSource.
initTable() - Method in class org.apache.hadoop.hbase.IntegrationTestIngest
 
initTable() - Method in class org.apache.hadoop.hbase.IntegrationTestIngestStripeCompactions
 
initTable() - Method in class org.apache.hadoop.hbase.IntegrationTestIngestWithMOB
 
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
 
initTableMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(TableName, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Class<? extends InputFormat>) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(byte[], Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableMap job.
initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a Multi TableMap job.
initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a Multi TableMap job.
initTableMapperJob(List<Scan>, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a Multi TableMap job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReduceJob(String, Class<? extends TableReduce>, JobConf, Class, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job, Class) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableReducerJob(String, Class<? extends TableReducer>, Job, Class, String, String, String, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Use this before submitting a TableReduce job.
initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTableSnapshotMapJob(String, String, Class<? extends TableMap>, Class<?>, Class<?>, JobConf, boolean, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTableSnapshotMapperJob(String, Scan, Class<? extends TableMapper>, Class<?>, Class<?>, Job, boolean, Path, RegionSplitter.SplitAlgorithm, int) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Sets up the job for reading from a table snapshot.
initTestTable() - Method in class org.apache.hadoop.hbase.util.LoadTestTool
 
INPUT_FAMILY - Static variable in class org.apache.hadoop.hbase.mapreduce.TestTableMapReduceBase
 
INPUT_FILES_SEPARATOR_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.WALPlayer
 
INPUT_TABLE - Static variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Job parameter that specifies the input table.
InputSplit() - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
InputSplit(TableDescriptor, HRegionInfo, List<String>, Scan, Path) - Constructor for class org.apache.hadoop.hbase.mapreduce.TableSnapshotInputFormatImpl.InputSplit
 
inputStream - Variable in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogReader
 
insertIntoNSTable(MasterProcedureEnv, NamespaceDescriptor) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
Insert the row into ns table
insertIntoNSTable(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
insertNewFiles(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
installed - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
 
instance() - Static method in class org.apache.hadoop.hbase.regionserver.SegmentFactory
 
instantiateFilter(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
Create a Filter to apply to all incoming keys (KeyValues) to optionally not include in the job output
instantiateHStore(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
instantiateMobFileCache(Configuration) - Static method in class org.apache.hadoop.hbase.mob.MobCacheConfig
Instantiates the MobFileCache.
instantiateRegionScanner(Scan, List<KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
instantiateRegionScanner(Scan, List<KeyValueScanner>, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
IntegrationTestAcidGuarantees - Class in org.apache.hadoop.hbase
This Integration Test verifies acid guarantees across column families by frequently writing values to rows with multiple column families and concurrently reading entire rows that expect all column families.
IntegrationTestAcidGuarantees() - Constructor for class org.apache.hadoop.hbase.IntegrationTestAcidGuarantees
 
IntegrationTestBackupRestore - Class in org.apache.hadoop.hbase
An integration test to detect regressions in HBASE-7912.
IntegrationTestBackupRestore() - Constructor for class org.apache.hadoop.hbase.IntegrationTestBackupRestore
 
IntegrationTestBase - Class in org.apache.hadoop.hbase
Base class for HBase integration tests that want to use the Chaos Monkey.
IntegrationTestBase() - Constructor for class org.apache.hadoop.hbase.IntegrationTestBase
 
IntegrationTestBase(String) - Constructor for class org.apache.hadoop.hbase.IntegrationTestBase
 
IntegrationTestBigLinkedList - Class in org.apache.hadoop.hbase.test
This is an integration test borrowed from goraci, written by Keith Turner, which is in turn inspired by the Accumulo test called continous ingest (ci).
IntegrationTestBigLinkedList() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedList
 
IntegrationTestBigLinkedListWithVisibility - Class in org.apache.hadoop.hbase.test
IT test used to verify the deletes with visibility labels.
IntegrationTestBigLinkedListWithVisibility() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedListWithVisibility
 
IntegrationTestBulkLoad - Class in org.apache.hadoop.hbase.mapreduce
Test Bulk Load and MR on a distributed cluster.
IntegrationTestBulkLoad() - Constructor for class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad
 
IntegrationTestBulkLoad.CompositeKeyComparator - Class in org.apache.hadoop.hbase.mapreduce
Comparator used to order linkKeys so that they are passed to a reducer in order.
IntegrationTestBulkLoad.EmptySplit - Class in org.apache.hadoop.hbase.mapreduce
 
IntegrationTestBulkLoad.FixedRecordReader<K,V> - Class in org.apache.hadoop.hbase.mapreduce
 
IntegrationTestBulkLoad.ITBulkLoadInputFormat - Class in org.apache.hadoop.hbase.mapreduce
 
IntegrationTestBulkLoad.LinkChain - Class in org.apache.hadoop.hbase.mapreduce
Writable used as the value emitted from a pass over the hbase table.
IntegrationTestBulkLoad.LinkedListCheckingMapper - Class in org.apache.hadoop.hbase.mapreduce
Mapper to pass over the table.
IntegrationTestBulkLoad.LinkedListCheckingReducer - Class in org.apache.hadoop.hbase.mapreduce
Class that does the actual checking of the links.
IntegrationTestBulkLoad.LinkedListCreationMapper - Class in org.apache.hadoop.hbase.mapreduce
Mapper that creates a linked list of KeyValues.
IntegrationTestBulkLoad.LinkKey - Class in org.apache.hadoop.hbase.mapreduce
Writable class used as the key to group links in the linked list.
IntegrationTestBulkLoad.NaturalKeyGroupingComparator - Class in org.apache.hadoop.hbase.mapreduce
Comparator used to figure out if a linkKey should be grouped together.
IntegrationTestBulkLoad.NaturalKeyPartitioner - Class in org.apache.hadoop.hbase.mapreduce
Class to figure out what partition to send a link in the chain to.
IntegrationTestBulkLoad.SlowMeCoproScanOperations - Class in org.apache.hadoop.hbase.mapreduce
 
IntegrationTestDDLMasterFailover - Class in org.apache.hadoop.hbase
Integration test that verifies Procedure V2.
IntegrationTestDDLMasterFailover() - Constructor for class org.apache.hadoop.hbase.IntegrationTestDDLMasterFailover
 
IntegrationTestImportTsv - Class in org.apache.hadoop.hbase.mapreduce
Validate ImportTsv + LoadIncrementalHFiles on a distributed cluster.
IntegrationTestImportTsv() - Constructor for class org.apache.hadoop.hbase.mapreduce.IntegrationTestImportTsv
 
IntegrationTestIngest - Class in org.apache.hadoop.hbase
A base class for tests that do something with the cluster while running LoadTestTool to write and verify some data.
IntegrationTestIngest() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngest
 
IntegrationTestIngestStripeCompactions - Class in org.apache.hadoop.hbase
A test class that does the same things as IntegrationTestIngest but with stripe compactions.
IntegrationTestIngestStripeCompactions() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngestStripeCompactions
 
IntegrationTestIngestWithACL - Class in org.apache.hadoop.hbase
/** An Integration class for tests that does something with the cluster while running LoadTestTool to write and verify some data.
IntegrationTestIngestWithACL() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngestWithACL
 
IntegrationTestIngestWithEncryption - Class in org.apache.hadoop.hbase
 
IntegrationTestIngestWithEncryption() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngestWithEncryption
 
IntegrationTestIngestWithMOB - Class in org.apache.hadoop.hbase
Integration Test for MOB ingest.
IntegrationTestIngestWithMOB() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngestWithMOB
 
IntegrationTestIngestWithTags - Class in org.apache.hadoop.hbase
 
IntegrationTestIngestWithTags() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngestWithTags
 
IntegrationTestIngestWithVisibilityLabels - Class in org.apache.hadoop.hbase
 
IntegrationTestIngestWithVisibilityLabels() - Constructor for class org.apache.hadoop.hbase.IntegrationTestIngestWithVisibilityLabels
 
IntegrationTestingUtility - Class in org.apache.hadoop.hbase
Facility for integration/system tests.
IntegrationTestingUtility() - Constructor for class org.apache.hadoop.hbase.IntegrationTestingUtility
 
IntegrationTestingUtility(Configuration) - Constructor for class org.apache.hadoop.hbase.IntegrationTestingUtility
 
IntegrationTestLazyCfLoading - Class in org.apache.hadoop.hbase
Integration test that verifies lazy CF loading during scans by doing repeated scans with this feature while multiple threads are continuously writing values; and verifying the result.
IntegrationTestLazyCfLoading() - Constructor for class org.apache.hadoop.hbase.IntegrationTestLazyCfLoading
 
IntegrationTestLoadAndVerify - Class in org.apache.hadoop.hbase.test
A large test which loads a lot of data that has internal references, and verifies the data.
IntegrationTestLoadAndVerify() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify
 
IntegrationTestLoadAndVerify.LoadMapper - Class in org.apache.hadoop.hbase.test
 
IntegrationTestLoadAndVerify.VerifyMapper - Class in org.apache.hadoop.hbase.test
 
IntegrationTestLoadAndVerify.VerifyReducer - Class in org.apache.hadoop.hbase.test
 
IntegrationTestLoadAndVerify.WALSearcher - Class in org.apache.hadoop.hbase.test
Tool to search missing rows in WALs and hfiles.
IntegrationTestLoadAndVerify.WALSearcher.WALMapperSearcher - Class in org.apache.hadoop.hbase.test
The actual searcher mapper.
IntegrationTestManyRegions - Class in org.apache.hadoop.hbase
An integration test to detect regressions in HBASE-7220.
IntegrationTestManyRegions() - Constructor for class org.apache.hadoop.hbase.IntegrationTestManyRegions
 
IntegrationTestMetaReplicas - Class in org.apache.hadoop.hbase
An integration test that starts the cluster with three replicas for the meta It then creates a table, flushes the meta, kills the server holding the primary.
IntegrationTestMetaReplicas() - Constructor for class org.apache.hadoop.hbase.IntegrationTestMetaReplicas
 
IntegrationTestMonkeys - Class in org.apache.hadoop.hbase.test
This is an integration test for showing a simple usage of how to use Monkeys to control ChaosMonkeyRunner.
IntegrationTestMonkeys() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestMonkeys
 
IntegrationTestMTTR - Class in org.apache.hadoop.hbase.mttr
Integration test that should benchmark how fast HBase can recover from failures.
IntegrationTestMTTR() - Constructor for class org.apache.hadoop.hbase.mttr.IntegrationTestMTTR
 
IntegrationTestMTTR.LoadCallable - Class in org.apache.hadoop.hbase.mttr
Callable used to make sure the cluster has some load on it.
IntegrationTestRegionReplicaPerf - Class in org.apache.hadoop.hbase
Test for comparing the performance impact of region replicas.
IntegrationTestRegionReplicaPerf() - Constructor for class org.apache.hadoop.hbase.IntegrationTestRegionReplicaPerf
 
IntegrationTestRegionReplicaReplication - Class in org.apache.hadoop.hbase
Integration test for testing async wal replication to secondary region replicas.
IntegrationTestRegionReplicaReplication() - Constructor for class org.apache.hadoop.hbase.IntegrationTestRegionReplicaReplication
 
IntegrationTestRegionReplicaReplication.DelayingMultiThreadedUpdater - Class in org.apache.hadoop.hbase
This extends MultiThreadedWriter to add a configurable delay to the keys written by the writer threads to become available to the MultiThradedReader threads.
IntegrationTestRegionReplicaReplication.DelayingMultiThreadedWriter - Class in org.apache.hadoop.hbase
This extends MultiThreadedWriter to add a configurable delay to the keys written by the writer threads to become available to the MultiThradedReader threads.
IntegrationTestReplication - Class in org.apache.hadoop.hbase.test
This is an integration test for replication.
IntegrationTestReplication() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestReplication
 
IntegrationTestReplication.ClusterID - Class in org.apache.hadoop.hbase.test
Wrapper around an HBase ClusterID allowing us to get admin connections and configurations for it
IntegrationTestReplication.VerifyReplicationLoop - Class in org.apache.hadoop.hbase.test
The main runner loop for the test.
IntegrationTestRpcClient - Class in org.apache.hadoop.hbase.ipc
 
IntegrationTestRpcClient() - Constructor for class org.apache.hadoop.hbase.ipc.IntegrationTestRpcClient
 
IntegrationTestRSGroup - Class in org.apache.hadoop.hbase.rsgroup
Runs all of the units tests defined in TestGroupBase as an integration test.
IntegrationTestRSGroup() - Constructor for class org.apache.hadoop.hbase.rsgroup.IntegrationTestRSGroup
 
IntegrationTestsDriver - Class in org.apache.hadoop.hbase
This class drives the Integration test suite execution.
IntegrationTestsDriver() - Constructor for class org.apache.hadoop.hbase.IntegrationTestsDriver
 
IntegrationTestSendTraceRequests - Class in org.apache.hadoop.hbase.trace
 
IntegrationTestSendTraceRequests() - Constructor for class org.apache.hadoop.hbase.trace.IntegrationTestSendTraceRequests
 
IntegrationTestSparkBulkLoad - Class in org.apache.hadoop.hbase.spark
Test Bulk Load and Spark on a distributed cluster.
IntegrationTestSparkBulkLoad() - Constructor for class org.apache.hadoop.hbase.spark.IntegrationTestSparkBulkLoad
 
IntegrationTestSparkBulkLoad.createCombinerFunc - Class in org.apache.hadoop.hbase.spark
 
IntegrationTestSparkBulkLoad.LinkedListCheckingFlatMapFunc - Class in org.apache.hadoop.hbase.spark
PairFlatMapFunction used to transfer to Tuple
IntegrationTestSparkBulkLoad.LinkedListCheckingForeachFunc - Class in org.apache.hadoop.hbase.spark
Sort all LinkChain for one LinkKey, and test List
IntegrationTestSparkBulkLoad.LinkedListCreationMapper - Class in org.apache.hadoop.hbase.spark
 
IntegrationTestSparkBulkLoad.ListToKeyValueFunc - Class in org.apache.hadoop.hbase.spark
 
IntegrationTestSparkBulkLoad.mergeCombinersFunc - Class in org.apache.hadoop.hbase.spark
 
IntegrationTestSparkBulkLoad.mergeValueFunc - Class in org.apache.hadoop.hbase.spark
 
IntegrationTestSparkBulkLoad.NaturalKeyPartitioner - Class in org.apache.hadoop.hbase.spark
Class to figure out what partition to send a link in the chain to.
IntegrationTestSparkBulkLoad.SparkLinkChain - Class in org.apache.hadoop.hbase.spark
Writable used as the value emitted from a pass over the hbase table.
IntegrationTestSparkBulkLoad.SparkLinkKey - Class in org.apache.hadoop.hbase.spark
Writable class used as the key to group links in the linked list.
IntegrationTestTableMapReduceUtil - Class in org.apache.hadoop.hbase.mapreduce
Test that we add tmpjars correctly including the named dependencies.
IntegrationTestTableMapReduceUtil() - Constructor for class org.apache.hadoop.hbase.mapreduce.IntegrationTestTableMapReduceUtil
 
IntegrationTestTableSnapshotInputFormat - Class in org.apache.hadoop.hbase.mapreduce
An integration test to test TableSnapshotInputFormat which enables reading directly from snapshot files without going through hbase servers.
IntegrationTestTableSnapshotInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.IntegrationTestTableSnapshotInputFormat
 
IntegrationTestTimeBoundedMultiGetRequestsWithRegionReplicas - Class in org.apache.hadoop.hbase.test
Extends IntegrationTestTimeBoundedRequestsWithRegionReplicas for multi-gets Besides the options already talked about in IntegrationTestTimeBoundedRequestsWithRegionReplicas the addition options here are:
IntegrationTestTimeBoundedMultiGetRequestsWithRegionReplicas() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedMultiGetRequestsWithRegionReplicas
 
IntegrationTestTimeBoundedRequestsWithRegionReplicas - Class in org.apache.hadoop.hbase.test
An IntegrationTest for doing reads with a timeout, to a read-only table with region replicas.
IntegrationTestTimeBoundedRequestsWithRegionReplicas() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas
 
IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader - Class in org.apache.hadoop.hbase.test
 
IntegrationTestTimeBoundedRequestsWithRegionReplicas.TimeBoundedMultiThreadedReader.TimeBoundedMultiThreadedReaderThread - Class in org.apache.hadoop.hbase.test
 
IntegrationTestWithCellVisibilityLoadAndVerify - Class in org.apache.hadoop.hbase.test
A large test which loads a lot of data with cell visibility, and verifies the data.
IntegrationTestWithCellVisibilityLoadAndVerify() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestWithCellVisibilityLoadAndVerify
 
IntegrationTestWithCellVisibilityLoadAndVerify.LoadWithCellVisibilityMapper - Class in org.apache.hadoop.hbase.test
 
IntegrationTestWithCellVisibilityLoadAndVerify.VerifyMapper - Class in org.apache.hadoop.hbase.test
 
IntegrationTestZKAndFSPermissions - Class in org.apache.hadoop.hbase.test
An integration test which checks that the znodes in zookeeper and data in the FileSystem are protected for secure HBase deployments.
IntegrationTestZKAndFSPermissions() - Constructor for class org.apache.hadoop.hbase.test.IntegrationTestZKAndFSPermissions
 
internalAdd(Cell, boolean, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
 
internalAdd(Cell, boolean, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
internalDoWork() - Method in class org.apache.hadoop.hbase.trace.IntegrationTestSendTraceRequests
 
internalFlushcache(WAL, long, Collection<HStore>, MonitoredTask, boolean, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Flush the memstore.
internalFlushCacheAndCommit(WAL, MonitoredTask, HRegion.PrepareFlushResult, Collection<HStore>) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
internalPrepareFlushCache(WAL, long, Collection<HStore>, MonitoredTask, boolean, FlushLifeCycleTracker) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
internalRunIngestTest(long) - Method in class org.apache.hadoop.hbase.IntegrationTestIngest
 
InternalScan - Class in org.apache.hadoop.hbase.regionserver
Special scanner, currently used for increment operations to allow additional server-side arguments for Scan operations.
InternalScan(Get) - Constructor for class org.apache.hadoop.hbase.regionserver.InternalScan
 
InternalScan(Scan) - Constructor for class org.apache.hadoop.hbase.regionserver.InternalScan
 
InternalScanner - Interface in org.apache.hadoop.hbase.regionserver
Internal scanners differ from client-side scanners in that they operate on HStoreKeys and byte[] instead of RowResults.
interrupt() - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
 
invert(float[][]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
Copy a given matrix into a new matrix, transforming each row index and each column index according to the inverse of the randomization scheme that was created at construction time.
invertIndices(int[]) - Method in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrix
Given an array where each element indices[i] represents the randomized column index corresponding to randomized row index i, create a new array with the corresponding inverted indices.
IPC_SERVER_MAX_CALLQUEUE_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcScheduler
 
IPC_SERVER_PRIORITY_MAX_CALLQUEUE_LENGTH - Static variable in class org.apache.hadoop.hbase.ipc.RpcScheduler
 
IS_ACTIVE_MASTER_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
IS_ACTIVE_MASTER_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
 
IS_DISTRIBUTED_CLUSTER - Static variable in class org.apache.hadoop.hbase.IntegrationTestingUtility
Configuration that controls whether this utility assumes a running/deployed cluster.
isAborted() - Method in class org.apache.hadoop.hbase.mapreduce.TestMultiTableInputFormatBase.MRSplitsConnection
 
isAborted() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isAborted() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
isAborted() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner.WarnOnlyAbortable
 
isAborted() - Method in class org.apache.hadoop.hbase.SharedConnection
 
isActive() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
 
isActiveMaster() - Method in class org.apache.hadoop.hbase.master.HMaster
Report whether this master is currently the active master or not.
isActiveMaster() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
isAlive() - Method in class org.apache.hadoop.hbase.http.HttpServer
Test for the availability of the web server
isAllFiles() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
isAllFiles() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
 
isAutoFlush() - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
 
isAvailable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isBalancerEnabled(RpcController, IsBalancerEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isBalancerOn() - Method in class org.apache.hadoop.hbase.master.HMaster
Queries the state of the LoadBalancerTracker.
isBatchUpdate - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
 
isBrowser(String) - Method in class org.apache.hadoop.hbase.rest.filter.RestCsrfPreventionFilter
This method interrogates the User-Agent String and returns whether it refers to a browser.
isBulkLoaded() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
 
isCacheMobBlocks(Scan) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Indicates whether the scan contains the information of caching blocks.
isCarryingMeta(ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
isCatalogJanitorEnabled(RpcController, IsCatalogJanitorEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isCheckOnlyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
Returns true if only the MemStore should be checked.
isCheckOnlyStoreFiles() - Method in class org.apache.hadoop.hbase.regionserver.InternalScan
Returns true if only StoreFiles should be checked.
isCleanerChoreEnabled(RpcController, IsCleanerChoreEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isClientCellBlockSupported() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
If the client connected and specified a codec to use, then we will use this codec making cellblocks to return.
isClosed() - Method in class org.apache.hadoop.hbase.mapreduce.TestMultiTableInputFormatBase.MRSplitsConnection
 
isClosed() - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.RegionCloseOperation
 
isClosed() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isClosed() - Method in class org.apache.hadoop.hbase.SharedConnection
 
isClosing() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isClusterUp() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
isClusterUp() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isClusterUp() - Method in interface org.apache.hadoop.hbase.regionserver.RegionServerServices
 
isCodelQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
isCompactionNeeded() - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.FlushResult
 
isCompactionNeeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
Convenience method, the equivalent of checking if result is FLUSHED_COMPACTION_NEEDED.
isDead - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
 
isDeadlineQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
isDeadServer(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
 
isDeleted(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
Check if the specified cell buffer has been deleted by a previously seen delete.
isDeleted(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
This method is not idempotent, we will save some info to judge VERSION_MASKED.
isDeleted(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
Check if the specified Cell buffer has been deleted by a previously seen delete.
isDelFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isDestructive() - Method in class org.apache.hadoop.hbase.chaos.monkies.CalmChaosMonkey
 
isDestructive() - Method in class org.apache.hadoop.hbase.chaos.monkies.ChaosMonkey
Returns whether the CM does destructive actions (killing servers) so that a cluster restore is needed after CM is stopped.
isDestructive() - Method in class org.apache.hadoop.hbase.chaos.monkies.PolicyBasedChaosMonkey
 
isDistributedCluster() - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
 
isDistributedCluster() - Method in class org.apache.hadoop.hbase.IntegrationTestingUtility
 
isDone(long) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker
Give the tracker a chance to declare it's done based on only the timestamp to allow an early out.
isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ExplicitColumnTracker
 
isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
 
isDone(long) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanWildcardColumnTracker
 
isDone(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isDone() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isDone() - Method in class org.apache.hadoop.hbase.tool.Canary.Monitor
 
isEmpty() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
isEmpty() - Method in class org.apache.hadoop.hbase.master.DeadServer
 
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap
 
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
 
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
 
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreSize
 
isEmpty() - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker
 
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker
 
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
 
isEmpty() - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
isEmpty() - Method in class org.apache.hadoop.hbase.rest.client.Cluster
 
isEnabled(Configuration) - Static method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
 
isEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
If throttling is enabled
isErr(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isErr() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isFailedOpen() - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher.RegionOpenOperation
 
isFailoverCleanupDone() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
Used by ServerCrashProcedure to make sure AssignmentManager has completed the failover cleanup before re-assigning regions of dead servers.
isFamilyEssential(byte[]) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
isFifoQueueType(String) - Static method in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
Should the master delete the file or keep it?
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.HFileLinkCleaner
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveProcedureWALCleaner
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
 
isFileDeletable(FileStatus) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
 
isFileScanner() - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
 
isFileScanner() - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
 
isFilterDone() - Method in interface org.apache.hadoop.hbase.regionserver.RegionScanner
 
isFinished() - Method in class org.apache.hadoop.hbase.master.snapshot.TakeSnapshotHandler
 
isFinished() - Method in interface org.apache.hadoop.hbase.master.SnapshotSentinel
Check to see if the snapshot is finished, where finished may be success or failure.
isFinished() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceShipper
 
isFinished() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
 
isFlushCommits() - Method in class org.apache.hadoop.hbase.rest.PerformanceEvaluation.PeInputSplit
 
isFlushSucceeded() - Method in interface org.apache.hadoop.hbase.regionserver.HRegion.FlushResult
 
isFlushSucceeded() - Method in class org.apache.hadoop.hbase.regionserver.HRegion.FlushResultImpl
Convenience method, the equivalent of checking if result is FLUSHED_NO_COMPACTION_NEEDED or FLUSHED_NO_COMPACTION_NEEDED.
isGet() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NormalUserScanQueryMatcher
 
isGet() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.RawScanQueryMatcher
 
isGet() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
isHFile(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isHttpEnabled() - Method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
 
isHttpsEnabled() - Method in enum org.apache.hadoop.hbase.http.HttpConfig.Policy
 
isInitialized() - Method in class org.apache.hadoop.hbase.master.HMaster
Report whether this master has completed with its initialization and is ready.
isInitialized() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
isInitialized() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
isInitOnly - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
 
isInMaintenanceMode() - Method in class org.apache.hadoop.hbase.master.HMaster
Report whether this master is in maintenance mode.
isInMaintenanceMode() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
isInRpcCallContext() - Static method in class org.apache.hadoop.hbase.ipc.RpcServer
 
isInState(State...) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionStateNode
 
isInState(RegionStates.ServerState...) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.ServerStateNode
 
isInstrumentationAccessAllowed(ServletContext, HttpServletRequest, HttpServletResponse) - Static method in class org.apache.hadoop.hbase.http.HttpServer
Checks the user has privileges to access to instrumentation servlets.
isInTransition() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionStateNode
 
isKilledRS(ServerName) - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
 
isLink() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isLoadingCfsOnDemandDefault() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isLocked() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
 
isLocked() - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
 
isMajor() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
isMajor() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
 
isMasterInMaintenanceMode(RpcController, IsInMaintenanceModeRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isMasterRunning(RpcController, IsMasterRunningRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isMergeable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isMeta() - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
 
isMetaInitialized() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
isMetaLoaded() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
isMetaRegionInTransition() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
isMobFileExpired(ColumnFamilyDescriptor, long, String) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Checks if the mob file is expired.
isMobReferenceCell(Cell) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Whether the current cell is a mob reference cell.
isMobRegionInfo(RegionInfo) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Gets whether the current RegionInfo is a mob one.
isMobRegionName(TableName, byte[]) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Gets whether the current region name follows the pattern of a mob region name.
isMultiPut - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
 
isNormalizerEnabled(RpcController, IsNormalizerEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isNormalizerOn() - Method in class org.apache.hadoop.hbase.master.HMaster
Queries the state of the RegionNormalizerTracker.
isOffHeap() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
 
isOffHeap() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
 
isOffHeap() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
 
isOffheapMemStore() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.TunerContext
 
isOffPeak() - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
 
isOffPeak() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl
 
isOffPeakHour(int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
 
isOffPeakHour() - Method in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
 
isOnHeap() - Method in class org.apache.hadoop.hbase.regionserver.ImmutableMemStoreLAB
 
isOnHeap() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
 
isOnHeap() - Method in class org.apache.hadoop.hbase.regionserver.MemStoreLABImpl
 
isOnline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
Report the status of the server.
isOnline() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
isOnline() - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Whether the manager is able to fully return group metadata
isOnlineSchemaChangeSupported() - Method in enum org.apache.hadoop.hbase.executor.EventType
 
isOperationRunning() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
isOperationRunning() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Indicates to the client whether this task is monitoring a currently active RPC call to a database command.
isOrphan() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
isOwned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isOwned() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
 
isPeerEnabled() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
check whether the peer is enabled or not
isPeerEnabled() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
 
isPrimaryReplicaReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileReader
 
isPrimaryReplicaStore() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
isPrimaryReplicaStore() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
isProcedureDone(RpcController, IsProcedureDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Checks if the specified procedure is done.
isProcedureDone(ProcedureDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
isRawMobScan(Scan) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Indicates whether it's a raw scan.
isRead - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
 
isReadable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.consumer.ProtobufMessageBodyConsumer
 
isReadEmptyValueOnMobCellMiss(Scan) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Indicates whether return null value when the mob file is missing or corrupt.
isReaderRunning() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
 
isReadOnly() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isReady() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPRequestStream
 
isReady() - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseStream
 
isRecoverySupported() - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
 
isReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isReference(Path) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isRefOnlyScan(Scan) - Static method in class org.apache.hadoop.hbase.mob.MobUtils
Indicates whether it's a reference only scan.
isRegionInRegionStates(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
 
isRegionInServerManagerStates(RegionInfo) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
isRegionInState(RegionInfo, State...) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
 
isRegionInTransition(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
 
isRegionOffline(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
 
isRegionOnline(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
 
isRegionOverThreshold(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
 
isRegionStale(String, long) - Method in class org.apache.hadoop.hbase.regionserver.StorefileRefresherChore
 
isRegionTwiceOverThreshold(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager.RegionInTransitionStat
 
isResigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isResigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isRetryImmediatelySupported() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
 
isRollbackSupported(RegionTransitionState) - Method in class org.apache.hadoop.hbase.master.assignment.AssignProcedure
 
isRollbackSupported(MergeTableRegionsState) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
 
isRollbackSupported(RegionTransitionState) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
 
isRollbackSupported(SplitTableRegionState) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
 
isRollbackSupported(RegionTransitionState) - Method in class org.apache.hadoop.hbase.master.assignment.UnassignProcedure
 
isRollbackSupported(CloneSnapshotState) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
 
isRollbackSupported(CreateNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
isRollbackSupported(CreateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
isRollbackSupported(DeleteNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteNamespaceProcedure
 
isRollbackSupported(DeleteTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
isRollbackSupported(DisableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
 
isRollbackSupported(EnableTableState) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
 
isRollbackSupported(ModifyNamespaceState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyNamespaceProcedure
 
isRollbackSupported(ModifyTableState) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
isRollbackSupported(RestoreSnapshotState) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
 
isRollbackSupported(TruncateTableState) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
 
isRPCRunning() - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredRPCHandler
 
isRPCRunning() - Method in class org.apache.hadoop.hbase.monitoring.MonitoredRPCHandlerImpl
Indicates to the client whether this task is monitoring a currently active RPC call.
isRunning(ClusterManager.ServiceType, String, int) - Method in class org.apache.hadoop.hbase.HBaseClusterManager
 
isRunning() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
isRunning() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv
 
isRunning() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Returns true if this service is RUNNING.
isRunning(ClusterManager.ServiceType, String, int) - Method in class org.apache.hadoop.hbase.RESTApiClusterManager
 
isSecure() - Method in class org.apache.hadoop.hbase.http.HttpConfig
 
isSecurityEnabled - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
isServerCrashProcessingEnabled() - Method in class org.apache.hadoop.hbase.master.HMaster
ServerCrashProcessingEnabled is set false before completing assignMeta to prevent processing of crashed servers.
isServerCrashProcessingEnabled() - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
isServerDead(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
Check if a server is known to be dead.
isServerOnline(MasterProcedureEnv, RegionStates.RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
 
isServerOnline(MasterProcedureEnv, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
 
isServerOnline(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
 
isShowQueueDump(Configuration) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
 
isSingleRow() - Method in class org.apache.hadoop.hbase.rest.RowSpec
 
isSkipInit - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
 
isSloppy() - Method in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
 
isSloppy() - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
 
isSloppy() - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
 
isSloppyMemStore() - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
isSloppyMemStore() - Method in interface org.apache.hadoop.hbase.regionserver.Store
 
isSnapshotDone(RpcController, IsSnapshotDoneRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
Checks if the specified snapshot is done.
isSnapshotDone(SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
Check if the specified snapshot is done
isSourceActive() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
isSourceActive() - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
 
isSplitable(JobContext, Path) - Method in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat
 
isSplitOrMergeEnabled(MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.HMaster
Queries the state of the SplitOrMergeTracker.
isSplitOrMergeEnabled(RpcController, IsSplitOrMergeEnabledRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
isSplitOrMergeEnabled(MasterSwitchType) - Method in interface org.apache.hadoop.hbase.master.MasterServices
 
isSplitOrMergeEnabled(MasterSwitchType) - Method in class org.apache.hadoop.hbase.master.SplitOrMergeTracker
 
isSplittable() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
isStarted() - Method in class org.apache.hadoop.hbase.ipc.RpcServer
 
isStarted() - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
 
isStarting() - Method in class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
isStarting() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
 
isStopped() - Method in class org.apache.hadoop.hbase.chaos.monkies.CalmChaosMonkey
 
isStopped() - Method in class org.apache.hadoop.hbase.chaos.monkies.ChaosMonkey
 
isStopped() - Method in class org.apache.hadoop.hbase.chaos.monkies.PolicyBasedChaosMonkey
 
isStopped() - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
isStopped() - Method in class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
 
isStopped() - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveLogCleaner
 
isStopped() - Method in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveProcedureWALCleaner
 
isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotFileCache
 
isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotHFileCleaner
 
isStopped() - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
isStopped() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
isStopped() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isStopped() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer.MovedRegionsCleaner
 
isStopped() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationHFileCleaner
 
isStopped() - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
 
isStopped() - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
 
isStopping() - Method in class org.apache.hadoop.hbase.chaos.actions.Action.ActionContext
 
isStopping() - Method in class org.apache.hadoop.hbase.chaos.policies.Policy.PolicyContext
 
isStopping() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
isStopping() - Method in interface org.apache.hadoop.hbase.Server
 
isStuck() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionStateNode
 
isSystemTable() - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates.RegionStateNode
 
isSystemTablesOnlyOnMaster(Configuration) - Static method in interface org.apache.hadoop.hbase.master.LoadBalancer
 
isTableAvailable(String) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
isTableAvailable(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
 
isTableAvailableAndInitialized() - Method in class org.apache.hadoop.hbase.master.TableNamespaceManager
This method checks if the namespace table is assigned and then tries to create its Table reference.
isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
isTablePresent(TableName) - Method in class org.apache.hadoop.hbase.master.TableStateManager
 
isTablesOnMaster(Configuration) - Static method in interface org.apache.hadoop.hbase.master.LoadBalancer
 
isTableState(TableName, TableState.State...) - Method in class org.apache.hadoop.hbase.master.TableStateManager
 
isTagsPresent() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
 
isTagsPresent() - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
isTopReference() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
 
isUnassigned() - Method in class org.apache.hadoop.hbase.master.SplitLogManager.Task
 
isUnassigned(ServerName) - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isUnassigned() - Method in class org.apache.hadoop.hbase.SplitLogTask
 
isUpdate - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
 
isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.CompactionScanQueryMatcher
 
isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher
 
isUserScan() - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.UserScanQueryMatcher
 
isUseTags() - Method in class org.apache.hadoop.hbase.rest.PerformanceEvaluation.PeInputSplit
 
isValid(FileStatus) - Static method in class org.apache.hadoop.hbase.regionserver.StoreFileInfo
Return if the specified file is a valid store file or not.
isValidArguements(String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.ExportUtils
 
isValidState(ScannerContext.NextState) - Static method in enum org.apache.hadoop.hbase.regionserver.ScannerContext.NextState
 
isWrite - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.PlainTextMessageBodyProducer
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class org.apache.hadoop.hbase.rest.provider.producer.ProtobufMessageBodyProducer
 
isWriteToWAL() - Method in class org.apache.hadoop.hbase.rest.PerformanceEvaluation.PeInputSplit
 
isYieldBeforeExecuteFromState(MasterProcedureEnv, ServerCrashState) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
For this procedure, yield at end of each successful flow step so that all crashed servers can make progress rather than do the default which has each procedure running to completion before we move to the next.
ITBulkLoadInputFormat() - Constructor for class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad.ITBulkLoadInputFormat
 
iter - Variable in class org.apache.hadoop.hbase.regionserver.SegmentScanner
 
iterator() - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache
 
iterator() - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
iterator() - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
iterator() - Method in class org.apache.hadoop.hbase.regionserver.CompositeImmutableSegment
 
iterator() - Method in class org.apache.hadoop.hbase.regionserver.Segment
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
Skip navigation links
Hortonworks Data Platform 3.0.0