- D - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'D'
- DaemonThreadFactory - Class in org.apache.hadoop.hbase
-
Thread factory that creates daemon threads
- DaemonThreadFactory(String) - Constructor for class org.apache.hadoop.hbase.DaemonThreadFactory
-
- DamagedWALException - Exception in org.apache.hadoop.hbase.regionserver.wal
-
Thrown when a failed append or sync on a WAL.
- DamagedWALException() - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
-
- DamagedWALException(String) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
-
- DamagedWALException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
-
- DamagedWALException(Throwable) - Constructor for exception org.apache.hadoop.hbase.regionserver.wal.DamagedWALException
-
- data() - Static method in class org.apache.hadoop.hbase.io.hfile.bucket.TestBucketCache
-
- data() - Static method in class org.apache.hadoop.hbase.io.hfile.TestLazyDataBlockDecompression
-
- data() - Static method in class org.apache.hadoop.hbase.regionserver.compactions.PerfTestCompactionPolicies
-
- data - Variable in class org.apache.hadoop.hbase.regionserver.TestStripeCompactor.StoreFileWritersCapture.Writer
-
- data() - Static method in class org.apache.hadoop.hbase.TestRegionRebalancing
-
- DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- DATA_BLOCK_ENCODING - Static variable in interface org.apache.hadoop.hbase.io.hfile.HFileDataBlockEncoder
-
Type of encoding used for data blocks in HFile.
- DATA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- DATA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer
-
- DATA_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellMessage.Cell
-
- DATA_FILE_UMASK_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
File permission umask to use when creating hbase data files
- DATA_INDEX_COUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileTrailerProto
-
- DATA_LOCALITY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad
-
- DATA_SIZE_WITHOUT_WAL - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- DATA_SIZE_WITHOUT_WAL_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- dataAvailable - Variable in class org.apache.hadoop.hbase.wal.WALSplitter.PipelineController
-
- DATABLOCK_ENCODING_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat
-
Deprecated.
- DATABLOCK_ENCODING_OVERRIDE_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.HFileOutputFormat2
-
- DataBlockEncoder - Interface in org.apache.hadoop.hbase.io.encoding
-
Encoding of KeyValue.
- dataBlockEncoder - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
What kind of data block encoding should be used while reading, writing,
and handling cache.
- DataBlockEncoder.EncodedSeeker - Interface in org.apache.hadoop.hbase.io.encoding
-
An interface which enable to seek while underlying data is encoded.
- DataBlockEncoding - Enum in org.apache.hadoop.hbase.io.encoding
-
Provide access to all data block encoding algorithms.
- dataBlockEncoding - Variable in class org.apache.hadoop.hbase.util.TestMiniClusterLoadSequential
-
- dataBlockEncodingAlgo - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- DataBlockEncodingTool - Class in org.apache.hadoop.hbase.regionserver
-
Tests various algorithms for key compression on an existing HFile.
- DataBlockEncodingTool(String) - Constructor for class org.apache.hadoop.hbase.regionserver.DataBlockEncodingTool
-
- dataBlockIndexReader - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Data block index reader keeping the root data index in memory
- dataBlockReadCnt - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
- dataGenerator - Variable in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
- DataOutputOutputStream - Class in org.apache.hadoop.hbase.io
-
OutputStream implementation that wraps a DataOutput.
- DataType<T> - Interface in org.apache.hadoop.hbase.types
-
DataType
is the base class for all HBase data types.
- DATE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.VersionInfo
-
- DAY_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Seconds in a day, hour and minute
- DAYS_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TimeUnit
-
DAYS = 7;
- DEAD_REGION_SERVERS_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- DEAD_REGION_SERVERS_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- DEAD_SERVERS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus
-
- DEADNODES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- DeadServer - Class in org.apache.hadoop.hbase.master
-
Class to hold dead servers list and utility querying dead server list.
- DeadServer() - Constructor for class org.apache.hadoop.hbase.master.DeadServer
-
- deadServers - Variable in class org.apache.hadoop.hbase.master.handler.LogReplayHandler
-
- deadServers - Variable in class org.apache.hadoop.hbase.master.handler.ServerShutdownHandler
-
- debugLsr(Configuration, Path) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
ls -r for debugging purposes
- debugLsr(Configuration, Path, HBaseFsck.ErrorReporter) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
-
ls -r for debugging purposes
- decGauge(String, long) - Method in interface org.apache.hadoop.hbase.metrics.BaseSource
-
Subtract some amount from a gauge.
- decGauge(String, long) - Method in class org.apache.hadoop.hbase.metrics.BaseSourceImpl
-
Decrease the value of a named gauge.
- DECLARING_CLASS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.StackTraceElementMessage
-
- decode(PositionedByteRange) - Method in interface org.apache.hadoop.hbase.types.DataType
-
Read an instance of T
from the buffer src
.
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.FixedLengthWrapper
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBlob
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedString
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.PBCell
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawByte
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
- decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytes
-
Read a byte[]
from the buffer src
.
- decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesFixedLength
-
Read a byte[]
from the buffer src
.
- decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.RawBytesTerminated
-
Read a byte[]
from the buffer src
.
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawDouble
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawFloat
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawInteger
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawLong
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawShort
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.RawString
-
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Struct
-
- decode(PositionedByteRange, int) - Method in class org.apache.hadoop.hbase.types.Struct
-
Read the field at index
.
- decode(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.TerminatedWrapper
-
- DECODE - Static variable in class org.apache.hadoop.hbase.util.Base64
-
Specify decoding.
- decode(byte[], int, int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Very low-level access to decoding ASCII characters in the form of a byte
array.
- decode(String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Decodes data from Base64 notation, automatically detecting gzip-compressed
data and decompressing it.
- decode(String, int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Decodes data from Base64 notation, automatically detecting gzip-compressed
data and decompressing it.
- decode4to3(byte[], int, byte[], int, int) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Decodes four bytes from array source and writes the resulting
bytes (up to three of them) to destination.
- decodeA(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union2
-
Read an instance of the first type parameter from buffer src
.
- decodeB(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union2
-
Read an instance of the second type parameter from buffer src
.
- decodeBlobCopy(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a Blob value, byte-for-byte copy.
- decodeBlobVar(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a blob value that was encoded using BlobVar encoding.
- decodeByte(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt8
-
Read a byte
value from the buffer src
.
- decodeByte(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawByte
-
Read a byte
value from the buffer buff
.
- decodeC(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union3
-
Read an instance of the third type parameter from buffer src
.
- decodeD(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.Union4
-
Read an instance of the fourth type parameter from buffer src
.
- decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat64
-
Read a double
value from the buffer src
.
- decodeDouble(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Read a double
value from the buffer src
.
- decodeDouble(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawDouble
-
Read a double
value from the buffer buff
.
- decodeFileToFile(String, String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Reads infile and decodes it to outfile.
- decodeFloat(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedFloat32
-
Read a float
value from the buffer dst
.
- decodeFloat(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawFloat
-
Read a float
value from the buffer buff
.
- decodeFloat32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a 32-bit floating point value using the fixed-length encoding.
- decodeFloat64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a 64-bit floating point value using the fixed-length encoding.
- decodeFromFile(String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Convenience method for reading a base64-encoded file and decoding it.
- decodeInt(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt32
-
Read an int
value from the buffer src
.
- decodeInt(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawInteger
-
Read an int
value from the buffer buff
.
- decodeInt16(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode an int16
value.
- decodeInt32(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode an int32
value.
- decodeInt64(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode an int64
value.
- decodeInt8(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode an int8
value.
- decodeKeyValues(DataInputStream, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
-
- decodeKeyValues(DataInputStream, int, int, HFileBlockDecodingContext) - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeCodec
-
I don't think this method is called during normal HBase operation, so efficiency is not
important.
- decodeKeyValues(DataInputStream, HFileBlockDecodingContext) - Method in interface org.apache.hadoop.hbase.io.encoding.DataBlockEncoder
-
Decode.
- decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt64
-
Read a long
value from the buffer src
.
- decodeLong(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedNumeric
-
Read a long
value from the buffer src
.
- decodeLong(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawLong
-
Read a long
value from the buffer buff
.
- decodeMemstoreTS - Variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
-
- decodeNumericAsBigDecimal(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a
BigDecimal
value from the variable-length encoding.
- decodeNumericAsDouble(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a primitive double
value from the Numeric encoding.
- decodeNumericAsLong(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a primitive long
value from the Numeric encoding.
- decodeRemoteException(RemoteException) - Static method in class org.apache.hadoop.hbase.RemoteExceptionHandler
-
- DecoderFactory - Class in org.apache.hadoop.hbase.codec.prefixtree.decode
-
Static wrapper class for the ArraySearcherPool.
- DecoderFactory() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.DecoderFactory
-
- decodeShort(PositionedByteRange) - Method in class org.apache.hadoop.hbase.types.OrderedInt16
-
Read a short
value from the buffer src
.
- decodeShort(byte[], int) - Method in class org.apache.hadoop.hbase.types.RawShort
-
Read a short
value from the buffer buff
.
- decodeString(PositionedByteRange) - Static method in class org.apache.hadoop.hbase.util.OrderedBytes
-
Decode a String value.
- decodeToFile(String, String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Convenience method for decoding data to a file.
- decodeToObject(String) - Static method in class org.apache.hadoop.hbase.util.Base64
-
Attempts to decode Base64 data and deserialize a Java Object within.
- decompress(byte[], int, InputStream, int, int, Compression.Algorithm) - Static method in class org.apache.hadoop.hbase.io.compress.Compression
-
Decompresses data from the given stream using the configured compression
algorithm.
- decorateMasterConfiguration(Configuration) - Static method in class org.apache.hadoop.hbase.replication.regionserver.Replication
-
This method modifies the master's configuration in order to inject
replication-related features
- decrement() - Method in class org.apache.hadoop.hbase.regionserver.ColumnCount
-
Decrement the current version count
- decrement() - Method in class org.apache.hadoop.hbase.util.Counter
-
- decRpcCount() - Method in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- decrSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSource
-
- decrSizeOfLogQueue(int) - Method in interface org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSource
-
- decrSizeOfLogQueue(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
-
- decrypt(byte[], int, InputStream, int, Decryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypt a block of ciphertext read in from a stream with the given
cipher and context
- decrypt(byte[], int, InputStream, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypt a block of ciphertext from a stream given a context and IV
- decrypt(OutputStream, InputStream, int, Decryptor) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypt a stream of ciphertext given a decryptor
- decrypt(OutputStream, InputStream, int, Encryption.Context, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypt a stream of ciphertext given a context and IV
- Decryptor - Interface in org.apache.hadoop.hbase.io.crypto
-
Decryptors apply a cipher to an InputStream to recover plaintext.
- decryptWithSubjectKey(OutputStream, InputStream, int, String, Configuration, Cipher, byte[]) - Static method in class org.apache.hadoop.hbase.io.crypto.Encryption
-
Decrypts a block of ciphertext with the symmetric key resolved for the given subject
- decScannerCount() - Method in class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
-
Called when closing a scanner on the data of this MemStoreLAB
- decScannerCount() - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Called when closing a scanner on the data of this MemStoreLAB
- DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
- DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- DEEP_OVERHEAD - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- deepClone() - Method in interface org.apache.hadoop.hbase.security.visibility.expression.ExpressionNode
-
- deepClone() - Method in class org.apache.hadoop.hbase.security.visibility.expression.LeafExpressionNode
-
- deepClone() - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.compact_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.enableTable_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getColumnDescriptors_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRegionInfo_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.increment_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.isTableEnabled_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.majorCompact_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerClose_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.IllegalArgument
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.IOError
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.Mutation
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TCell
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TColumn
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TRegionInfo
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TCellVisibility
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumn
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TColumnValue
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndPut_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.closeScanner_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.exists_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.get_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.increment_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.mutateRow_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.openScanner_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.put_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_result
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIllegalArgument
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TIOError
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- deepCopy() - Method in class org.apache.hadoop.hbase.thrift2.generated.TTimeRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- deepCopy() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Create a new ByteRange
with new backing byte[] containing a copy
of the content from this
range's window.
- deepCopy() - Method in interface org.apache.hadoop.hbase.util.PositionedByteRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.SimpleByteRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.SimpleMutableByteRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedByteRange
-
- deepCopy() - Method in class org.apache.hadoop.hbase.util.SimplePositionedMutableByteRange
-
- deepCopySubRangeTo(int, int, byte[], int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- deepCopySubRangeTo(int, int, byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Wrapper for System.arraycopy.
- deepCopyTo(byte[], int) - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- deepCopyTo(byte[], int) - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Wrapper for System.arraycopy.
- deepCopyToNewArray() - Method in class org.apache.hadoop.hbase.util.AbstractByteRange
-
- deepCopyToNewArray() - Method in interface org.apache.hadoop.hbase.util.ByteRange
-
Instantiate a new byte[] with exact length, which is at least 24 bytes +
length.
- DEFAUL_CHAOS_MONKEY_DELAY - Static variable in class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas
-
- DEFAULT_ABORT_ON_ERROR - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- DEFAULT_ATTRIBUTE_EARLY_OUT - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
-
Default setting for hbase.security.access.early_out
- DEFAULT_ATTRIBUTES_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- DEFAULT_BASE_TEST_DIRECTORY - Static variable in class org.apache.hadoop.hbase.HBaseCommonTestingUtility
-
Default base directory for test output.
- DEFAULT_BATCH_RESTART_RS_RATIO - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_BATCH_RESTART_RS_SLEEP_TIME - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_BATCH_SIZE - Static variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
-
Default batch size for multigets
- DEFAULT_BLOCKCACHE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to use a block cache or not.
- DEFAULT_BLOCKING_STOREFILE_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default size of blocks in files stored to the filesytem (hfiles).
- DEFAULT_BLOCKSIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default block size for an HFile.
- DEFAULT_BLOOMFILTER - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether or not to use bloomfilters.
- DEFAULT_BUCKET_CACHE_COMBINED - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
Defaults for Bucket cache
- DEFAULT_BUCKET_CACHE_WRITER_QUEUE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_BUCKET_CACHE_WRITER_THREADS - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
The number of bytes per checksum.
- DEFAULT_BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- DEFAULT_BYTES_PER_CHECKSUM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to cache bloom filter blocks on write if block
caching is enabled.
- DEFAULT_CACHE_BLOOMS_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_CACHE_DATA_COMPRESSED - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_CACHE_DATA_IN_L1 - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to cache data blocks in L1 tier.
- DEFAULT_CACHE_DATA_ON_READ - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to cache data blocks on write if block caching
is enabled.
- DEFAULT_CACHE_DATA_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_CACHE_FLUSH_INTERVAL - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
Default interval for the memstore flush
- DEFAULT_CACHE_INDEX_ON_WRITE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to cache index blocks on write if block
caching is enabled.
- DEFAULT_CACHE_INDEXES_ON_WRITE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_CELL_TTL_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- DEFAULT_CELL_VISIBILITY_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- DEFAULT_CF_BYTES - Static variable in class org.apache.hadoop.hbase.HTestConst
-
- DEFAULT_CF_STR - Static variable in class org.apache.hadoop.hbase.HTestConst
-
- DEFAULT_CF_STR_SET - Static variable in class org.apache.hadoop.hbase.HTestConst
-
- DEFAULT_CHECKSUM_TYPE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
- DEFAULT_CHECKSUM_TYPE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileContext
-
- DEFAULT_CHECKSUM_TYPE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileContextBuilder
-
- DEFAULT_CLUSTER_DISTRIBUTED - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for cluster distributed mode
- DEFAULT_CLUSTER_ID - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default cluster ID, cannot be used to identify a cluster so a key with
this value means it wasn't meant for replication.
- DEFAULT_CODEC_CLASS - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- DEFAULT_COLUMN_FAMILIES - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
Column families used by the test
- DEFAULT_COLUMN_FAMILY - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
Column family used by the test
- DEFAULT_COMPACT_RANDOM_REGION_RATIO - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_COMPACT_TABLE_ACTION_RATIO - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_COMPACTCHECKER_INTERVAL_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.regionserver.HStore
-
- DEFAULT_COMPACTION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Constant that denotes whether the table is compaction enabled by default
- DEFAULT_COMPACTION_POLICY_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
-
- DEFAULT_COMPACTOR_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
-
- DEFAULT_COMPOSITE_ACTION3_PERIOD - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_COMPRESS_TAGS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default compress tags along with any type of DataBlockEncoding.
- DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default compression type.
- DEFAULT_COMPRESSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Default compression name: none.
- DEFAULT_COMPRESSION_ALGORITHM - Static variable in class org.apache.hadoop.hbase.io.hfile.HFile
-
Default compression: none.
- DEFAULT_CONCURRENCY_LEVEL - Static variable in class org.apache.hadoop.hbase.util.WeakObjectPool
-
The default concurrency level,
used when not otherwise specified in a constructor.
- DEFAULT_COPROCESSORS_ENABLED - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- DEFAULT_DATA_BLOCK_ENCODING - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default data block encoding algorithm.
- DEFAULT_DATA_SIZE - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
The default data size if not specified
- DEFAULT_DISALLOW_WRITES_IN_RECOVERING_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_DISTRIBUTED_LOG_REPLAY_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_ENABLE_CLIENT_BACKPRESSURE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_ENCODE_ON_DISK - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default value of the flag that enables data block encoding on disk, as
opposed to encoding in cache only.
- DEFAULT_END_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.rest.RowSpec
-
- DEFAULT_ERROR_TOLERATION_DURATION - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
-
- DEFAULT_EVICT_BLOCKS_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to evict cached blocks from the blockcache on
close.
- DEFAULT_EVICT_ON_CLOSE - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_EXEC_PERMISSION_CHECKS - Static variable in interface org.apache.hadoop.hbase.security.access.AccessControlConstants
-
Default setting for hbase.security.exec.permission.checks; false
- DEFAULT_FLUSH_PER_CHANGES - Static variable in class org.apache.hadoop.hbase.regionserver.HRegion
-
- DEFAULT_GET_TIMEOUT - Static variable in class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas
-
- DEFAULT_HBASE_CELLS_SCANNED_PER_HEARTBEAT_CHECK - Static variable in class org.apache.hadoop.hbase.regionserver.StoreScanner
-
- DEFAULT_HBASE_CLIENT_MAX_PERREGION_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_MAX_PERSERVER_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_MAX_TOTAL_TASKS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_OPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default HBase client operation timeout, which is tantamount to a blocking call
- DEFAULT_HBASE_CLIENT_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_RETRIES_NUMBER - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CLIENT_SCANNER_MAX_RESULT_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum number of bytes returned when calling a scanner's next method.
- DEFAULT_HBASE_CLIENT_SCANNER_TIMEOUT_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_CONFIG_READ_ZOOKEEPER_CONFIG - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_HTTP_STATIC_USER - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
-
- DEFAULT_HBASE_JETTY_LOGS_SERVE_ALIASES - Static variable in interface org.apache.hadoop.hbase.http.ServerConfigurationKeys
-
- DEFAULT_HBASE_META_BLOCK_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_META_SCANNER_CACHING - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_META_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_RPC_SHORTOPERATION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_RPC_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_SERVER_PAUSE - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HBASE_SERVER_SCANNER_MAX_RESULT_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Maximum number of bytes returned when calling a scanner's next method.
- DEFAULT_HEALTH_FAILURE_THRESHOLD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HEALTH_SCRIPT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HEAP_OCCUPANCY_HIGH_WATERMARK - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HEAP_OCCUPANCY_LOW_WATERMARK - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HOST - Static variable in class org.apache.hadoop.hbase.HConstants
-
default host address
- DEFAULT_HREGION_EDITS_REPLAY_SKIP_ERRORS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_HREGION_MEMSTORE_BLOCK_MULTIPLIER - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for hbase.hregion.memstore.block.multiplier
- DEFAULT_HSTORE_OPEN_AND_CLOSE_THREADS_MAX - Static variable in class org.apache.hadoop.hbase.HConstants
-
The default number for the max number of threads used for opening and
closing stores or store files in parallel
- DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for whether to try and serve this column family from memory or not.
- DEFAULT_IN_MEMORY - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_INITIAL_CAPACITY - Static variable in class org.apache.hadoop.hbase.util.WeakObjectPool
-
The default initial capacity,
used when not otherwise specified in a constructor.
- DEFAULT_KEEP_DELETED - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default setting for preventing deleted from being collected immediately.
- DEFAULT_KEY_WINDOW - Static variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
-
Default "window" size between the last key written by the writer and the
key that we attempt to read.
- DEFAULT_KEYVALUE_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Strings
-
- DEFAULT_LISTEN_PORT - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- DEFAULT_LISTEN_PORT - Static variable in class org.apache.hadoop.hbase.thrift.ThriftServerRunner
-
- DEFAULT_LISTEN_PORT - Static variable in class org.apache.hadoop.hbase.thrift2.ThriftServer
-
- DEFAULT_LOCAL_DIR - Static variable in class org.apache.hadoop.hbase.util.ClassLoaderBase
-
- DEFAULT_MASTER_HANLDER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_MASTER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
default port for master web api
- DEFAULT_MASTER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
default port that the master listens on
- DEFAULT_MASTER_TYPE_BACKUP - Static variable in class org.apache.hadoop.hbase.HConstants
-
by default every master is a possible primary master unless the conf explicitly overrides it
- DEFAULT_MATH_CONTEXT - Static variable in class org.apache.hadoop.hbase.util.OrderedBytes
-
- DEFAULT_MAX - Static variable in class org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile
-
- DEFAULT_MAX_AGE - Static variable in interface org.apache.hadoop.hbase.rest.Constants
-
- DEFAULT_MAX_BACKOFF - Static variable in class org.apache.hadoop.hbase.client.backoff.ExponentialClientBackoffPolicy
-
- DEFAULT_MAX_ERRORS - Static variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
-
Default maximum number of read errors to tolerate before shutting down all
readers.
- DEFAULT_MAX_FILE_SIZE - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default maximum file size
- DEFAULT_MAX_QUEUED_REQUESTS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- DEFAULT_MAX_RESUBMIT - Static variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- DEFAULT_MAX_SPLITTERS - Static variable in interface org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination
-
- DEFAULT_MAX_WAIT_TIME - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotDescriptionUtils
-
By default, wait 300 seconds for a snapshot to complete
- DEFAULT_MAX_WORKER_THREADS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
- DEFAULT_MEMSTORE_FLUSH_SIZE - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Constant that denotes the maximum default size of the memstore after which
the contents are flushed to the store files
- DEFAULT_MEMSTORE_SIZE - Static variable in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
-
- DEFAULT_MEMSTORE_SIZE_LOWER_LIMIT - Static variable in class org.apache.hadoop.hbase.io.util.HeapMemorySizeUtil
-
- DEFAULT_META_REPLICA_NUM - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_MIN_MASTER_PROCEDURE_THREADS - Static variable in class org.apache.hadoop.hbase.master.procedure.MasterProcedureConstants
-
- DEFAULT_MIN_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default is not to keep a minimum of versions.
- DEFAULT_MIN_WORKER_THREADS - Static variable in class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer
-
This default core pool size should be enough for many test scenarios.
- DEFAULT_MOVE_RANDOM_REGION_SLEEP_TIME - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_MOVE_REGIONS_MAX_TIME - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_MOVE_REGIONS_SLEEP_TIME - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_NAMESPACE - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- DEFAULT_NAMESPACE_NAME - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
Default namespace name.
- DEFAULT_NAMESPACE_NAME_STR - Static variable in class org.apache.hadoop.hbase.NamespaceDescriptor
-
- DEFAULT_NORMALIZATION_ENABLED - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Constant that denotes whether the table is normalized by default.
- DEFAULT_NUM_KEYS_PER_SERVER - Static variable in class org.apache.hadoop.hbase.IntegrationTestIngest
-
- DEFAULT_NUM_READ_THREADS - Static variable in class org.apache.hadoop.hbase.IntegrationTestIngest
-
- DEFAULT_NUM_REGIONS - Static variable in class org.apache.hadoop.hbase.IntegrationTestDDLMasterFailover
-
- DEFAULT_NUM_REGIONS_PER_SERVER - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- DEFAULT_NUM_THREADS - Static variable in class org.apache.hadoop.hbase.IntegrationTestDDLMasterFailover
-
- DEFAULT_NUM_THREADS - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
The number of reader/writer threads if not specified
- DEFAULT_NUM_WRITE_THREADS - Static variable in class org.apache.hadoop.hbase.IntegrationTestIngest
-
- DEFAULT_NUMBER_OF_SEEKS - Static variable in class org.apache.hadoop.hbase.regionserver.EncodedSeekPerformanceTest
-
Default number of seeks which will be used in benchmark.
- DEFAULT_PERIODIC_ACTION1_PERIOD - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_PERIODIC_ACTION2_PERIOD - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_PERIODIC_ACTION4_PERIOD - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_PREFETCH_BLOCKS_ON_OPEN - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
- DEFAULT_PREFETCH_ON_OPEN - Static variable in class org.apache.hadoop.hbase.io.hfile.CacheConfig
-
- DEFAULT_QUALIFIER_BYTES - Static variable in class org.apache.hadoop.hbase.HTestConst
-
- DEFAULT_QUALIFIER_STR - Static variable in class org.apache.hadoop.hbase.HTestConst
-
- DEFAULT_READONLY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
Constant that denotes whether the table is READONLY by default and is false
- DEFAULT_REGION_COUNT - Static variable in class org.apache.hadoop.hbase.IntegrationTestManyRegions
-
- DEFAULT_REGION_MEMSTORE_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
- DEFAULT_REGION_REPLICA_WAIT_FOR_PRIMARY_FLUSH - Static variable in class org.apache.hadoop.hbase.client.RegionReplicaUtil
-
- DEFAULT_REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
- DEFAULT_REGION_REPLICATION - Static variable in class org.apache.hadoop.hbase.test.IntegrationTestTimeBoundedRequestsWithRegionReplicas
-
- DEFAULT_REGION_SERVER_HANDLER_ABORT_ON_ERROR_PERCENT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGION_SERVER_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGION_SERVER_HIGH_PRIORITY_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGION_SERVER_REGION_SPLIT_LIMIT - Static variable in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- DEFAULT_REGION_SERVER_REPLICATION_HANDLER_COUNT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGIONS_PER_SERVER - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
-
The default number of regions per regionserver when creating a pre-split
table.
- DEFAULT_REGIONSERVER_COUNT - Static variable in class org.apache.hadoop.hbase.IntegrationTestManyRegions
-
- DEFAULT_REGIONSERVER_INFOPORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
default port for region server web api
- DEFAULT_REGIONSERVER_METRICS_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_REGIONSERVER_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default port region server listens on.
- DEFAULT_REPLICA_ID - Static variable in class org.apache.hadoop.hbase.HRegionInfo
-
- DEFAULT_REPLICATION_SCOPE - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default scope.
- DEFAULT_RESTART_ACTIVE_MASTER_SLEEP_TIME - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_RESTART_RANDOM_RS_SLEEP_TIME - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_RESTART_RS_HOLDING_META_SLEEP_TIME - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_ROLLING_BATCH_RESTART_RS_RATIO - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_ROLLING_BATCH_RESTART_RS_SLEEP_TIME - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_ROW_BYTES - Static variable in class org.apache.hadoop.hbase.HTestConst
-
- DEFAULT_ROW_STR - Static variable in class org.apache.hadoop.hbase.HTestConst
-
- DEFAULT_RUN_TIME - Static variable in class org.apache.hadoop.hbase.IntegrationTestDDLMasterFailover
-
- DEFAULT_RUN_TIME - Static variable in class org.apache.hadoop.hbase.IntegrationTestIngest
-
- DEFAULT_SEPARATOR - Static variable in class org.apache.hadoop.hbase.util.Strings
-
- DEFAULT_SLEEP_BEFORE_RERUN - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
- DEFAULT_SLOW_RESPONSE_NANO_SEC - Static variable in class org.apache.hadoop.hbase.thrift.ThriftMetrics
-
- DEFAULT_SOCKET_TIMEOUT_CONNECT - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- DEFAULT_SOCKET_TIMEOUT_READ - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- DEFAULT_SOCKET_TIMEOUT_WRITE - Static variable in interface org.apache.hadoop.hbase.ipc.RpcClient
-
- DEFAULT_START_KEY - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- DEFAULT_START_TIMESTAMP - Static variable in class org.apache.hadoop.hbase.rest.RowSpec
-
- DEFAULT_STATUS_MULTICAST_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_STATUS_MULTICAST_BIND_ADDRESS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_STATUS_MULTICAST_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_STATUS_PUBLISH_PERIOD - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- DEFAULT_STATUS_PUBLISHER_CLASS - Static variable in class org.apache.hadoop.hbase.master.ClusterStatusPublisher
-
- DEFAULT_STORE_FLUSHER_CLASS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
-
- DEFAULT_TABLE - Static variable in class org.apache.hadoop.hbase.HTestConst
-
- DEFAULT_TABLE_BYTES - Static variable in class org.apache.hadoop.hbase.HTestConst
-
- DEFAULT_TABLE_LOCK_EXPIRE_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
-
- DEFAULT_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedList
-
- DEFAULT_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
Table name to use of not overridden on the command line
- DEFAULT_TABLE_READ_LOCK_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
-
- DEFAULT_TABLE_STR - Static variable in class org.apache.hadoop.hbase.HTestConst
-
- DEFAULT_TABLE_WRITE_LOCK_TIMEOUT_MS - Static variable in class org.apache.hadoop.hbase.master.TableLockManager
-
- DEFAULT_TABLES_COUNT - Static variable in class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedListWithVisibility
-
- DEFAULT_THREAD_WAKE_FREQUENCY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for thread wake frequency
- DEFAULT_TIME_LAG - Static variable in class org.apache.hadoop.hbase.util.HBaseFsck
-
- DEFAULT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- DEFAULT_TIMEOUT_MINUTES - Static variable in class org.apache.hadoop.hbase.IntegrationTestManyRegions
-
- DEFAULT_TIMESTAMP_COLUMN_INDEX - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default time to live of cell contents.
- DEFAULT_TTL - Static variable in class org.apache.hadoop.hbase.master.cleaner.TimeToLiveHFileCleaner
-
- DEFAULT_TYPE - Static variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- DEFAULT_UNASSIGNED_TIMEOUT - Static variable in class org.apache.hadoop.hbase.master.SplitLogManager
-
- DEFAULT_UNBALANCE_CHAOS_EVERY_MS - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_UNBALANCE_WAIT_AFTER_BALANCE_MS - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_UNBALANCE_WAIT_FOR_KILLS_MS - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_UNBALANCE_WAIT_FOR_UNBALANCE_MS - Static variable in interface org.apache.hadoop.hbase.chaos.factories.MonkeyConstants
-
- DEFAULT_USE_META_REPLICAS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_USER_COPROCESSORS_ENABLED - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- DEFAULT_VALUE_BYTES - Static variable in class org.apache.hadoop.hbase.HTestConst
-
- DEFAULT_VALUE_LENGTH - Static variable in class org.apache.hadoop.hbase.PerformanceEvaluation
-
- DEFAULT_VALUE_STR - Static variable in class org.apache.hadoop.hbase.HTestConst
-
- DEFAULT_VERSION_FILE_WRITE_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Parameter name for how often we should try to write a version file, before failing
- DEFAULT_VERSIONS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
-
Default number of versions of a record to keep.
- DEFAULT_WAL_STORAGE_POLICY - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_ZK_RETRIES - Static variable in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- DEFAULT_ZK_SESSION_TIMEOUT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default value for ZooKeeper session timeout
- DEFAULT_ZOOKEEPER_ZNODE_PARENT - Static variable in class org.apache.hadoop.hbase.HConstants
-
- DEFAULT_ZOOKEPER_CLIENT_PORT - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default client port that the zookeeper listens on
- DEFAULT_ZOOKEPER_MAX_CLIENT_CNXNS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default limit on concurrent client-side zookeeper connections
- DEFAULT_ZOOKEPER_RECOVERABLE_WAITIME - Static variable in class org.apache.hadoop.hbase.HConstants
-
Default wait time for the recoverable zookeeper
- DefaultCipherProvider - Class in org.apache.hadoop.hbase.io.crypto
-
The default cipher provider.
- DefaultCompactor - Class in org.apache.hadoop.hbase.regionserver.compactions
-
Compact passed set of files.
- DefaultCompactor(Configuration, Store) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
-
- defaultContexts - Variable in class org.apache.hadoop.hbase.http.HttpServer
-
- DefaultDataGenerator(int, int, int, int, byte[]...) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator
-
- DefaultDataGenerator(byte[]...) - Constructor for class org.apache.hadoop.hbase.util.MultiThreadedAction.DefaultDataGenerator
-
- DefaultEnvironmentEdge - Class in org.apache.hadoop.hbase.util
-
Default implementation of an environment edge.
- DefaultEnvironmentEdge() - Constructor for class org.apache.hadoop.hbase.util.DefaultEnvironmentEdge
-
- DefaultMemStore - Class in org.apache.hadoop.hbase.regionserver
-
The MemStore holds in-memory modifications to the Store.
- DefaultMemStore() - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Default constructor.
- DefaultMemStore(Configuration, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Constructor.
- DefaultMemStore.MemStoreScanner - Class in org.apache.hadoop.hbase.regionserver
-
- DefaultMetaScannerVisitor() - Constructor for class org.apache.hadoop.hbase.client.MetaScanner.DefaultMetaScannerVisitor
-
- DefaultOperationQuota - Class in org.apache.hadoop.hbase.quotas
-
- DefaultOperationQuota(QuotaLimiter...) - Constructor for class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- DefaultOperationQuota(List<QuotaLimiter>) - Constructor for class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
NOTE: The order matters.
- defaultPool(String, int) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Default thread pool for the procedure
- defaultPool(String, int, long) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Default thread pool for the procedure
- defaultPool(String, int) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Default thread pool for the procedure
- defaultPool(String, int, long) - Static method in class org.apache.hadoop.hbase.procedure.ProcedureMember
-
Default thread pool for the procedure
- DefaultStoreEngine - Class in org.apache.hadoop.hbase.regionserver
-
Default StoreEngine creates the default compactor, policy, and store file manager, or
their derivatives.
- DefaultStoreEngine() - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultStoreEngine
-
- DefaultStoreFlusher - Class in org.apache.hadoop.hbase.regionserver
-
Default implementation of StoreFlusher.
- DefaultStoreFlusher(Configuration, Store) - Constructor for class org.apache.hadoop.hbase.regionserver.DefaultStoreFlusher
-
- DefaultVisibilityExpressionResolver - Class in org.apache.hadoop.hbase.mapreduce
-
This implementation creates tags by expanding expression using label ordinal.
- DefaultVisibilityExpressionResolver() - Constructor for class org.apache.hadoop.hbase.mapreduce.DefaultVisibilityExpressionResolver
-
- DefaultVisibilityLabelServiceImpl - Class in org.apache.hadoop.hbase.security.visibility
-
- DefaultVisibilityLabelServiceImpl() - Constructor for class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- DefaultWALProvider - Class in org.apache.hadoop.hbase.wal
-
A WAL Provider that returns a single thread safe WAL that writes to HDFS.
- DefaultWALProvider() - Constructor for class org.apache.hadoop.hbase.wal.DefaultWALProvider
-
- DefaultWALProvider.Reader - Interface in org.apache.hadoop.hbase.wal
-
- DefaultWALProvider.Writer - Interface in org.apache.hadoop.hbase.wal
-
- DEFERRED_LOG_FLUSH - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
- deferredLogFlush - Variable in class org.apache.hadoop.hbase.util.LoadTestTool
-
- DefinedSetFilterScanLabelGenerator - Class in org.apache.hadoop.hbase.security.visibility
-
This is an implementation for ScanLabelGenerator.
- DefinedSetFilterScanLabelGenerator() - Constructor for class org.apache.hadoop.hbase.security.visibility.DefinedSetFilterScanLabelGenerator
-
- defineFilter(Context, String, String, Map<String, String>, String[]) - Static method in class org.apache.hadoop.hbase.http.HttpServer
-
Define a filter for a context and set up default url mappings.
- defMasterRMIRegistryPort - Static variable in class org.apache.hadoop.hbase.JMXListener
-
- defRegionserverRMIRegistryPort - Static variable in class org.apache.hadoop.hbase.JMXListener
-
- delAtTimestamp(String, long) - Method in class org.apache.hadoop.hbase.regionserver.TestSeekOptimizations
-
- DELAY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.ipc.protobuf.generated.TestDelayedRpcProtos.TestArg
-
- Delayable - Interface in org.apache.hadoop.hbase.ipc
-
A call whose response can be delayed by the server.
- DelayAnswer(Log) - Constructor for class org.apache.hadoop.hbase.GenericTestUtils.DelayAnswer
-
- DELAYED - Static variable in class org.apache.hadoop.hbase.ipc.TestDelayedRpc
-
- DelayingMultiThreadedUpdater(LoadTestDataGenerator, Configuration, TableName, double) - Constructor for class org.apache.hadoop.hbase.IntegrationTestRegionReplicaReplication.DelayingMultiThreadedUpdater
-
- DelayingMultiThreadedWriter(LoadTestDataGenerator, Configuration, TableName) - Constructor for class org.apache.hadoop.hbase.IntegrationTestRegionReplicaReplication.DelayingMultiThreadedWriter
-
- DelayingRunner<T> - Class in org.apache.hadoop.hbase.client
-
A wrapper for a runnable for a group of actions for a single regionserver.
- DelayingRunner(long, Map.Entry<byte[], List<Action<T>>>) - Constructor for class org.apache.hadoop.hbase.client.DelayingRunner
-
- delegate - Variable in class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
-
- DelegateAnswer(Object) - Constructor for class org.apache.hadoop.hbase.GenericTestUtils.DelegateAnswer
-
- DelegateAnswer(Log, Object) - Constructor for class org.apache.hadoop.hbase.GenericTestUtils.DelegateAnswer
-
- DelegatingPayloadCarryingRpcController - Class in org.apache.hadoop.hbase.ipc
-
- DelegatingPayloadCarryingRpcController(PayloadCarryingRpcController) - Constructor for class org.apache.hadoop.hbase.ipc.DelegatingPayloadCarryingRpcController
-
- DelegatingRetryingCallable<T,D extends RetryingCallable<T>> - Class in org.apache.hadoop.hbase.client
-
- DelegatingRetryingCallable(D) - Constructor for class org.apache.hadoop.hbase.client.DelegatingRetryingCallable
-
- Delete - Class in org.apache.hadoop.hbase.client
-
Used to perform Delete operations on a single row.
- Delete(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row.
- Delete(byte[], long) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row and timestamp.
- Delete(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row and timestamp.
- Delete(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
Create a Delete operation for the specified row and timestamp.
- Delete(Delete) - Constructor for class org.apache.hadoop.hbase.client.Delete
-
- delete(Delete) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deletes the specified cells/row.
- delete(List<Delete>) - Method in class org.apache.hadoop.hbase.client.HTable
-
Deletes the specified cells/rows in bulk.
- delete(Delete) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- delete(List<Delete>) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- delete(Delete) - Method in interface org.apache.hadoop.hbase.client.Table
-
Deletes the specified cells/row.
- delete(List<Delete>) - Method in interface org.apache.hadoop.hbase.client.Table
-
Deletes the specified cells/rows in bulk.
- delete(RpcController, BulkDeleteProtos.BulkDeleteRequest, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.example.BulkDeleteEndpoint
-
- delete(com.google.protobuf.RpcController, BulkDeleteProtos.BulkDeleteRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService.BlockingInterface
-
- delete(com.google.protobuf.RpcController, BulkDeleteProtos.BulkDeleteRequest, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService
-
rpc delete(.BulkDeleteRequest) returns (.BulkDeleteResponse);
- delete(com.google.protobuf.RpcController, BulkDeleteProtos.BulkDeleteRequest, <any>) - Method in interface org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService.Interface
-
rpc delete(.BulkDeleteRequest) returns (.BulkDeleteResponse);
- delete(com.google.protobuf.RpcController, BulkDeleteProtos.BulkDeleteRequest, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteService.Stub
-
- delete(Delete, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestCase.HRegionIncommon
-
Deprecated.
- delete(Delete, boolean) - Method in class org.apache.hadoop.hbase.HBaseTestCase.HTableIncommon
-
Deprecated.
- delete(Delete, boolean) - Method in interface org.apache.hadoop.hbase.HBaseTestCase.Incommon
-
Deprecated.
- delete(long) - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore
-
The specified procId was removed from the executor,
due to completion, abort or failure.
- delete(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- delete(long) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- delete(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
-
- delete(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Write a delete
- delete(Delete) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- delete(KeyValue) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Adds a value to the memstore
- delete(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Write a delete
- delete(Delete) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Deletes the specified cells/row.
- delete(String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a DELETE request
- delete(Cluster, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Send a DELETE request
- delete(Delete) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- delete(List<Delete>) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- delete(UriInfo) - Method in class org.apache.hadoop.hbase.rest.RowResource
-
- delete(UriInfo) - Method in class org.apache.hadoop.hbase.rest.ScannerInstanceResource
-
- delete(UriInfo) - Method in class org.apache.hadoop.hbase.rest.SchemaResource
-
- delete(HBaseTestCase.Incommon) - Static method in class org.apache.hadoop.hbase.TimestampTestBase
-
- delete(HBaseTestCase.Incommon, byte[]) - Static method in class org.apache.hadoop.hbase.TimestampTestBase
-
- delete(HBaseTestCase.Incommon, long) - Static method in class org.apache.hadoop.hbase.TimestampTestBase
-
- delete(HBaseTestCase.Incommon, byte[], long) - Static method in class org.apache.hadoop.hbase.TimestampTestBase
-
- delete(FileSystem, Path, boolean) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Calls fs.delete() and returns the value returned by the fs.delete()
- delete(String, int) - Method in class org.apache.hadoop.hbase.zookeeper.RecoverableZooKeeper
-
delete is an idempotent operation.
- DELETE_AFTER_LOAD_CONF - Static variable in class org.apache.hadoop.hbase.mapreduce.TestImportTsv
-
Delete the tmp directory after running doMROnTableTest.
- DELETE_AFTER_LOAD_CONF - Static variable in class org.apache.hadoop.hbase.mapreduce.TestImportTSVWithOperationAttributes
-
Delete the tmp directory after running doMROnTableTest.
- DELETE_AFTER_LOAD_CONF - Static variable in class org.apache.hadoop.hbase.mapreduce.TestImportTSVWithTTLs
-
Delete the tmp directory after running doMROnTableTest.
- DELETE_AFTER_LOAD_CONF - Static variable in class org.apache.hadoop.hbase.mapreduce.TestImportTSVWithVisibilityLabels
-
Delete the tmp directory after running doMROnTableTest.
- DELETE_COLUMN_FAMILY_DELETE_FS_LAYOUT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyState
-
DELETE_COLUMN_FAMILY_DELETE_FS_LAYOUT = 4;
- DELETE_COLUMN_FAMILY_IN_MODIFY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.ModifyTableStateData
-
- DELETE_COLUMN_FAMILY_POST_OPERATION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyState
-
DELETE_COLUMN_FAMILY_POST_OPERATION = 5;
- DELETE_COLUMN_FAMILY_PRE_OPERATION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyState
-
DELETE_COLUMN_FAMILY_PRE_OPERATION = 2;
- DELETE_COLUMN_FAMILY_PREPARE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyState
-
DELETE_COLUMN_FAMILY_PREPARE = 1;
- DELETE_COLUMN_FAMILY_REOPEN_ALL_REGIONS_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyState
-
DELETE_COLUMN_FAMILY_REOPEN_ALL_REGIONS = 6;
- DELETE_COLUMN_FAMILY_UPDATE_TABLE_DESCRIPTOR_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteColumnFamilyState
-
DELETE_COLUMN_FAMILY_UPDATE_TABLE_DESCRIPTOR = 3;
- DELETE_COLUMN_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellType
-
DELETE_COLUMN = 12;
- DELETE_FAMILY_COUNT - Static variable in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Delete Family Count in FileInfo
- DELETE_FAMILY_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellType
-
DELETE_FAMILY = 14;
- DELETE_FAMILY_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
-
DELETE_FAMILY = 2;
- DELETE_FAMILY_VERSION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
-
DELETE_FAMILY_VERSION = 3;
- DELETE_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- DELETE_MULTIPLE_VERSIONS_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
-
DELETE_MULTIPLE_VERSIONS = 1;
- DELETE_ONE_VERSION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.DeleteType
-
DELETE_ONE_VERSION = 0;
- DELETE_TABLE_CLEAR_FS_LAYOUT_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableState
-
DELETE_TABLE_CLEAR_FS_LAYOUT = 3;
- DELETE_TABLE_POST_OPERATION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableState
-
DELETE_TABLE_POST_OPERATION = 6;
- DELETE_TABLE_PRE_OPERATION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableState
-
DELETE_TABLE_PRE_OPERATION = 1;
- DELETE_TABLE_REMOVE_FROM_META_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableState
-
DELETE_TABLE_REMOVE_FROM_META = 2;
- DELETE_TABLE_UNASSIGN_REGIONS_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableState
-
DELETE_TABLE_UNASSIGN_REGIONS = 5;
- DELETE_TABLE_UPDATE_DESC_CACHE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableState
-
DELETE_TABLE_UPDATE_DESC_CACHE = 4;
- DELETE_TYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.QualifierValue
-
- DELETE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.CellProtos.CellType
-
DELETE = 8;
- DELETE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
-
DELETE = 3;
- DELETE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Type
-
DELETE = 5;
- deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, <any>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Delete all cells that match the passed row and column.
- deleteAll() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAll
-
- deleteAll(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- deleteAll_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- deleteAll_args(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
- deleteAll_args(Hbase.deleteAll_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Performs a deep copy on other.
- deleteAll_call(ByteBuffer, ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAll_call
-
- deleteAll_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- deleteAll_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
- deleteAll_result(Hbase.deleteAll_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_result
-
Performs a deep copy on other.
- deleteAllConnections(boolean) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- deleteAllConnections() - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
- deleteAllNodes(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes all unassigned nodes regardless of their state.
- deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, <any>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Completely delete the row's cells.
- deleteAllRow() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRow
-
- deleteAllRow(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- deleteAllRow_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- deleteAllRow_args(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
- deleteAllRow_args(Hbase.deleteAllRow_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Performs a deep copy on other.
- deleteAllRow_call(ByteBuffer, ByteBuffer, Map<ByteBuffer, ByteBuffer>, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRow_call
-
- deleteAllRow_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- deleteAllRow_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
- deleteAllRow_result(Hbase.deleteAllRow_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_result
-
Performs a deep copy on other.
- deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, <any>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Completely delete the row's cells marked with a timestamp
equal-to or older than the passed timestamp.
- deleteAllRowTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllRowTs
-
- deleteAllRowTs(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- deleteAllRowTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- deleteAllRowTs_args(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
- deleteAllRowTs_args(Hbase.deleteAllRowTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Performs a deep copy on other.
- deleteAllRowTs_call(ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllRowTs_call
-
- deleteAllRowTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- deleteAllRowTs_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
- deleteAllRowTs_result(Hbase.deleteAllRowTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_result
-
Performs a deep copy on other.
- deleteAllSnapshots(Admin) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
- deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, <any>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Delete all cells that match the passed row and column and whose
timestamp is equal-to or older than the passed timestamp.
- deleteAllTs() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteAllTs
-
- deleteAllTs(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- deleteAllTs_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- deleteAllTs_args(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
- deleteAllTs_args(Hbase.deleteAllTs_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Performs a deep copy on other.
- deleteAllTs_call(ByteBuffer, ByteBuffer, ByteBuffer, long, Map<ByteBuffer, ByteBuffer>, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteAllTs_call
-
- deleteAllTs_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- deleteAllTs_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
- deleteAllTs_result(Hbase.deleteAllTs_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_result
-
Performs a deep copy on other.
- deleteArchiveDirectory(HBaseTestingUtility) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
- deleteAssignmentState(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- DeleteAsyncCallback() - Constructor for class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination.DeleteAsyncCallback
-
- deleteBuffer - Variable in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
- deleteCachedRegionLocation(HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.ClusterConnection
-
Deletes cached locations for the specific region.
- deleteCachedRegionLocation(HRegionLocation) - Method in interface org.apache.hadoop.hbase.client.HConnection
-
- deleteChangedReaderObserver(ChangedReadersObserver) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- deleteChangedReaderObserver(ChangedReadersObserver) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- deleteChildrenRecursively(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete all the children of the specified node but not the node itself.
- deleteChildrenRecursivelyMultiOrSequential(ZooKeeperWatcher, boolean, String...) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete all the children of the specified node but not the node itself.
- deleteClosedNode(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the CLOSED state for the
specified region.
- deleteClosingNode(ZooKeeperWatcher, HRegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the CLOSING state for the
specified region.
- deleteClosingOrClosedNode(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
- deleteColumn(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete a column from a table.
- deleteColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
- deleteColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
- deleteColumn(byte[], String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete a column from a table.
- deleteColumn(String, String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete a column from a table.
- deleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete a column from a table.
- deleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- deleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Delete column of a table
- deleteColumn(RpcController, MasterProtos.DeleteColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- deleteColumn(TableName, byte[]) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Delete a column from an existing table
- deleteColumn(com.google.protobuf.RpcController, MasterProtos.DeleteColumnRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- deleteColumn(com.google.protobuf.RpcController, MasterProtos.DeleteColumnRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc DeleteColumn(.DeleteColumnRequest) returns (.DeleteColumnResponse);
- deleteColumn(com.google.protobuf.RpcController, MasterProtos.DeleteColumnRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc DeleteColumn(.DeleteColumnRequest) returns (.DeleteColumnResponse);
- deleteColumn(com.google.protobuf.RpcController, MasterProtos.DeleteColumnRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- deleteColumnFamilyFromFileSystem(MasterProcedureEnv, TableName, List<HRegionInfo>, byte[]) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterDDLOperationHelper
-
Remove the column family from the file system
- DeleteColumnFamilyProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
The procedure to delete a column family from an existing table.
- DeleteColumnFamilyProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- DeleteColumnFamilyProcedure(MasterProcedureEnv, TableName, byte[]) - Constructor for class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- deleteColumnFamilyTwice() - Method in class org.apache.hadoop.hbase.master.handler.TestTableDeleteFamilyHandler
-
- deleteColumnFamilyWithMultipleRegions() - Method in class org.apache.hadoop.hbase.master.handler.TestTableDeleteFamilyHandler
-
- deleteColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
- deleteColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
- deleteConnection(Configuration) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- DELETED_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode
-
- deleteDirectory(FileSystem, Path) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Delete if exists.
- deleteFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
- deleteFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
- deleteFamily(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Remove the region family from disk, archiving the store files.
- deleteFamilyBloomFilter - Variable in class org.apache.hadoop.hbase.regionserver.StoreFile.Reader
-
- deleteFamilyFromFS(HRegionInfo, byte[]) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- deleteFamilyVersion(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
- deleteFromFs(MasterProcedureEnv, TableName, List<HRegionInfo>, boolean) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- deleteFromHBase(Delete) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- deleteFromMeta(MasterProcedureEnv, TableName, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- deleteFromMetaTable(Connection, List<Delete>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Delete the passed deletes
from the hbase:meta
table.
- deleteFromThrift(TDelete) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- deleteIfEquals(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
-
delete the master znode if its content is same as the parameter
- deleteLength - Variable in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
- deleteMergeQualifiers(Connection, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Deletes merge qualifiers for the specified merged region.
- deleteMetaLocation(ZooKeeperWatcher) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
Deletes the location of hbase:meta
in ZooKeeper.
- deleteMetaLocation(ZooKeeperWatcher, int) - Method in class org.apache.hadoop.hbase.zookeeper.MetaTableLocator
-
- deleteMultiple(ByteBuffer, List<TDelete>, <any>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- deleteMultiple(ByteBuffer, List<TDelete>, <any>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- deleteMultiple(ByteBuffer, List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- deleteMultiple(ByteBuffer, List<TDelete>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Bulk commit a List of TDeletes to the table.
- deleteMultiple() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteMultiple
-
- deleteMultiple(ByteBuffer, List<TDelete>) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- deleteMultiple_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- deleteMultiple_args(ByteBuffer, List<TDelete>) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- deleteMultiple_args(THBaseService.deleteMultiple_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
Performs a deep copy on other.
- deleteMultiple_call(ByteBuffer, List<TDelete>, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteMultiple_call
-
- deleteMultiple_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- deleteMultiple_result(List<TDelete>, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- deleteMultiple_result(THBaseService.deleteMultiple_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
Performs a deep copy on other.
- deleteMyEphemeralNodeOnDisk() - Static method in class org.apache.hadoop.hbase.ZNodeClearer
-
delete the znode file
- deleteNamespace(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete an existing namespace.
- deleteNamespace(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete an existing namespace.
- deleteNamespace(String) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- deleteNamespace(RpcController, MasterProtos.DeleteNamespaceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- deleteNamespace(String) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Delete an existing namespace.
- deleteNamespace(String) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- deleteNamespace(com.google.protobuf.RpcController, MasterProtos.DeleteNamespaceRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- deleteNamespace(com.google.protobuf.RpcController, MasterProtos.DeleteNamespaceRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc DeleteNamespace(.DeleteNamespaceRequest) returns (.DeleteNamespaceResponse);
- deleteNamespace(com.google.protobuf.RpcController, MasterProtos.DeleteNamespaceRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc DeleteNamespace(.DeleteNamespaceRequest) returns (.DeleteNamespaceResponse);
- deleteNamespace(com.google.protobuf.RpcController, MasterProtos.DeleteNamespaceRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- deleteNamespace(HBaseTestingUtility, String) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- deleteNamespaceACLNode(String) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
Delete the acl notify node of namespace
- deleteNamespaceQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- deleteNode(ZooKeeperWatcher, String, EventType, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the specified state for the
specified region.
- deleteNode(ZooKeeperWatcher, String, EventType, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the specified state for the
specified region.
- deleteNode(ZooKeeperWatcher, String, EventType, ServerName, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the specified state for the
specified region.
- deleteNode(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete the specified node.
- deleteNode(ZooKeeperWatcher, String, int) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete the specified node with the specified version.
- deleteNodeFailSilent(ZooKeeperWatcher, HRegionInfo) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Delete the assignment node regardless of its current state.
- deleteNodeFailSilent(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Deletes the specified node.
- deleteNodeFailSilent(String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil.ZKUtilOp
-
- deleteNodeRecursively(ZooKeeperWatcher, String) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete the specified node and all of it's children.
- deleteNodeRecursivelyMultiOrSequential(ZooKeeperWatcher, boolean, String...) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Delete the specified node and its children.
- deleteNumericRows(HTable, byte[], int, int) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- deleteOfflineNode(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the OFFLINE state for the
specified region.
- deleteOffset - Variable in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
- deleteOpenedNode(ZooKeeperWatcher, String, ServerName) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Deletes an existing unassigned node that is in the OPENED state for the
specified region.
- deleteReader() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile
-
Delete this file
- deleteRecoveringRegionZNodes(ZooKeeperWatcher, List<String>) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKSplitLog
-
- deleteRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- deleteRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.RegionStates
-
Remove a region from all state maps.
- deleteRegion(Connection, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Deletes the specified region from META.
- deleteRegion(Configuration, Table, byte[], byte[]) - Method in class org.apache.hadoop.hbase.util.hbck.OfflineMetaRebuildTestCore
-
- deleteRegionDir(Configuration, HRegionInfo) - Static method in class org.apache.hadoop.hbase.util.FSUtils
-
Delete the region directory if exists.
- deleteRegionFromFileSystem(Configuration, FileSystem, Path, HRegionInfo) - Static method in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
-
Remove the region from the table directory, archiving the region's hfiles.
- deleteRegions(Connection, List<HRegionInfo>, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Deletes the specified regions from META.
- deleteRegions(Connection, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Deletes the specified regions from META.
- deleteRoot() - Method in class org.apache.hadoop.hbase.migration.NamespaceUpgrade
-
Remove the -ROOT- dir.
- deleteRow(String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- deletes - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
list of TDeletes to delete
- deletesFromThrift(List<TDelete>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
Converts multiple
TDelete
s (Thrift) into a list of
Delete
s (HBase).
- deleteShutdownHook(Runnable) - Static method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- deleteSingle(ByteBuffer, TDelete, <any>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- deleteSingle(ByteBuffer, TDelete, <any>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- deleteSingle - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.checkAndDelete_args
-
the TDelete to execute if the check succeeds
- deleteSingle(ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- deleteSingle - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
the TDelete to delete
- deleteSingle(ByteBuffer, TDelete) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
Deletes as specified by the TDelete.
- deleteSingle() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.deleteSingle
-
- deleteSingle(TDelete) - Static method in class org.apache.hadoop.hbase.thrift2.generated.TMutation
-
- deleteSingle(ByteBuffer, TDelete) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- deleteSingle_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- deleteSingle_args(ByteBuffer, TDelete) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
- deleteSingle_args(THBaseService.deleteSingle_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_args
-
Performs a deep copy on other.
- deleteSingle_call(ByteBuffer, TDelete, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.deleteSingle_call
-
- deleteSingle_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- deleteSingle_result(TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
- deleteSingle_result(THBaseService.deleteSingle_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteSingle_result
-
Performs a deep copy on other.
- deleteSnapshot(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete an existing snapshot.
- deleteSnapshot(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete an existing snapshot.
- deleteSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete an existing snapshot.
- deleteSnapshot(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete an existing snapshot.
- deleteSnapshot(RpcController, MasterProtos.DeleteSnapshotRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
Execute Delete Snapshot operation.
- deleteSnapshot(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
-
Delete the specified snapshot
- deleteSnapshot(com.google.protobuf.RpcController, MasterProtos.DeleteSnapshotRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- deleteSnapshot(com.google.protobuf.RpcController, MasterProtos.DeleteSnapshotRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc DeleteSnapshot(.DeleteSnapshotRequest) returns (.DeleteSnapshotResponse);
- deleteSnapshot(com.google.protobuf.RpcController, MasterProtos.DeleteSnapshotRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc DeleteSnapshot(.DeleteSnapshotRequest) returns (.DeleteSnapshotResponse);
- deleteSnapshot(com.google.protobuf.RpcController, MasterProtos.DeleteSnapshotRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- deleteSnapshots(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete existing snapshots whose names match the pattern passed.
- deleteSnapshots(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete existing snapshots whose names match the pattern passed.
- deleteSnapshots(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete existing snapshots whose names match the pattern passed.
- deleteSnapshots(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete existing snapshots whose names match the pattern passed.
- deleteSource(String, boolean) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Delete a complete queue of wals associated with a peer cluster
- deleteStaleConnection(HConnection) - Static method in class org.apache.hadoop.hbase.client.HConnectionManager
-
Deprecated.
- deleteTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Deletes a table.
- deleteTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- deleteTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deletes a table.
- deleteTable(String) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Drop an existing table
- deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Drop an existing table
- deleteTable(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Drop an existing table
- deleteTable(HBaseTestingUtility, TableName) - Static method in class org.apache.hadoop.hbase.master.handler.TestEnableTableHandler
-
- deleteTable(HBaseTestingUtility, HBaseAdmin, TableName) - Static method in class org.apache.hadoop.hbase.master.handler.TestEnableTableHandler
-
- deleteTable(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- deleteTable(TableName) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
- deleteTable(RpcController, MasterProtos.DeleteTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- deleteTable(TableName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Delete a table
- deleteTable(com.google.protobuf.RpcController, MasterProtos.DeleteTableRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- deleteTable(com.google.protobuf.RpcController, MasterProtos.DeleteTableRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc DeleteTable(.DeleteTableRequest) returns (.DeleteTableResponse);
- deleteTable(com.google.protobuf.RpcController, MasterProtos.DeleteTableRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc DeleteTable(.DeleteTableRequest) returns (.DeleteTableResponse);
- deleteTable(com.google.protobuf.RpcController, MasterProtos.DeleteTableRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- deleteTable(String) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
Deletes a table.
- deleteTable(byte[]) - Method in class org.apache.hadoop.hbase.rest.client.RemoteAdmin
-
Deletes a table.
- deleteTable(HBaseTestingUtility, TableName) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- deleteTable(HBaseTestingUtility, Admin, TableName) - Static method in class org.apache.hadoop.hbase.security.access.SecureTestUtil
-
- deleteTable() - Method in class org.apache.hadoop.hbase.StripeCompactionsPerformanceEvaluation
-
- deleteTable(ByteBuffer, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- deleteTable(ByteBuffer, <any>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- deleteTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- deleteTable(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Deletes a table
- deleteTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.deleteTable
-
- deleteTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- deleteTable(HBaseTestingUtility, TableName) - Static method in class org.apache.hadoop.hbase.util.TestHBaseFsck
-
- deleteTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- deleteTable_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
- deleteTable_args(Hbase.deleteTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_args
-
Performs a deep copy on other.
- deleteTable_call(ByteBuffer, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.deleteTable_call
-
- deleteTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- deleteTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
- deleteTable_result(Hbase.deleteTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteTable_result
-
Performs a deep copy on other.
- deleteTableACLNode(TableName) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
-
Delete the acl notify node of table
- deleteTableData(byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Provide an existing table name to truncate.
- deleteTableData(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Provide an existing table name to truncate.
- deleteTableDescriptorCache(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- deleteTableDescriptorIfExists(TableName) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Deletes all the table descriptor files from the file system.
- deleteTableDir(TableName) - Method in class org.apache.hadoop.hbase.util.TestHBaseFsck
-
- DeleteTableHandler - Class in org.apache.hadoop.hbase.master.handler
-
- DeleteTableHandler(TableName, Server, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.handler.DeleteTableHandler
-
- deleteTableIfAny(TableName) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Drop an existing table
- DeleteTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
- DeleteTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- DeleteTableProcedure(MasterProcedureEnv, TableName) - Constructor for class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- DeleteTableProcedure(MasterProcedureEnv, TableName, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- deleteTableQuota(Connection, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- deleteTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Deletes tables matching the passed in pattern and wait on completion.
- deleteTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Delete tables matching the passed in pattern and wait on completion.
- deleteTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Deletes tables matching the passed in pattern and wait on completion.
- deleteTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Delete tables matching the passed in pattern and wait on completion.
- deleteTableStates(MasterProcedureEnv, TableName) - Static method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- deleteTask(String) - Method in interface org.apache.hadoop.hbase.coordination.SplitLogManagerCoordination
-
- deleteTask(String) - Method in class org.apache.hadoop.hbase.coordination.ZKSplitLogManagerCoordination
-
- deleteTestDir(FileSystem) - Method in class org.apache.hadoop.hbase.io.hfile.TestSeekTo
-
- deleteTestDir() - Static method in class org.apache.hadoop.hbase.TestClassFinder
-
- deleteTimestamp - Variable in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
- DeleteTracker - Interface in org.apache.hadoop.hbase.regionserver
-
This interface is used for the tracking and enforcement of Deletes
during the course of a Get or Scan operation.
- DeleteTracker.DeleteCompare - Enum in org.apache.hadoop.hbase.regionserver
-
Return codes for comparison of two Deletes.
- DeleteTracker.DeleteResult - Enum in org.apache.hadoop.hbase.regionserver
-
Returns codes for delete result.
- deleteType - Variable in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
- deleteType - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- DELETETYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest
-
- deleteUserQuota(Connection, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- deleteUserQuota(Connection, String, TableName) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- deleteUserQuota(Connection, String, String) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- deleteValue(String, String, String) - Static method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- DeletionListener - Class in org.apache.hadoop.hbase.zookeeper
-
A ZooKeeper watcher meant to detect deletions of ZNodes.
- DeletionListener(ZooKeeperWatcher, String, CountDownLatch) - Constructor for class org.apache.hadoop.hbase.zookeeper.DeletionListener
-
Create a new instance of the deletion watcher.
- DelimitedKeyPrefixRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
A custom RegionSplitPolicy implementing a SplitPolicy that groups
rows by a prefix of the row-key with a delimiter.
- DelimitedKeyPrefixRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
- DELIMITER - Static variable in class org.apache.hadoop.hbase.HConstants
-
delimiter used between portions of a region name
- DELIMITER_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.DelimitedKeyPrefixRegionSplitPolicy
-
- DemoClient - Class in org.apache.hadoop.hbase.thrift
-
See the instructions under hbase-examples/README.txt
- DemoClient - Class in org.apache.hadoop.hbase.thrift2
-
- DemoClient() - Constructor for class org.apache.hadoop.hbase.thrift2.DemoClient
-
- deny(String, String, User, Permission.Action, String) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- deny(String, String, User, Permission.Action, TableName, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- deny(String, String, User, Permission.Action, TableName, Map<byte[], ? extends Collection<?>>) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- DependentColumnFilter - Class in org.apache.hadoop.hbase.filter
-
A filter for adding inter-column timestamp matching
Only cells with a correspondingly timestamped entry in
the target column will be retained
Not compatible with Scan.setBatch as operations need
full rows for correct filtering
- DependentColumnFilter(byte[], byte[], boolean, CompareFilter.CompareOp, ByteArrayComparable) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Build a dependent column filter with value checking
dependent column varies will be compared using the supplied
compareOp and comparator, for usage of which
refer to
CompareFilter
- DependentColumnFilter(byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Constructor for DependentColumn filter.
- DependentColumnFilter(byte[], byte[], boolean) - Constructor for class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
Constructor for DependentColumn filter.
- dequeuedCall(int) - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- dequeuedCall(int) - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- deregister(MetricsRegionSource) - Method in interface org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSource
-
Remove a region's source.
- deregister(MetricsRegionSource) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionAggregateSourceImpl
-
- deregisterChildren(ConfigurationManager) - Method in interface org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver
-
Needs to be called to deregister the children from the manager.
- deregisterChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
Needs to be called to deregister the children from the manager.
- deregisterChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Needs to be called to deregister the children from the manager.
- deregisterChildren(ConfigurationManager) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
Needs to be called to deregister the children from the manager.
- deregisterObserver(ConfigurationObserver) - Method in class org.apache.hadoop.hbase.conf.ConfigurationManager
-
Deregister an observer class
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
-
- DESCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
-
- descendingIterator() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- descendingSet() - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- descendToLastRowFromCurrentPosition() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayReversibleScanner
-
- DESCRIPTOR_VERSION - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV1
-
- DESCRIPTOR_VERSION - Static variable in class org.apache.hadoop.hbase.snapshot.SnapshotManifestV2
-
- DeserializationException - Exception in org.apache.hadoop.hbase.exceptions
-
Failed deserialization.
- DeserializationException() - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
-
- DeserializationException(String) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
-
- DeserializationException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
-
- DeserializationException(Throwable) - Constructor for exception org.apache.hadoop.hbase.exceptions.DeserializationException
-
- deserialize(byte[]) - Static method in exception org.apache.hadoop.hbase.errorhandling.ForeignException
-
Takes a series of bytes and tries to generate an ForeignException instance for it.
- deserialize(ByteBuffer) - Method in interface org.apache.hadoop.hbase.io.hfile.CacheableDeserializer
-
Returns the deserialized object.
- deserialize(ByteBuffer, boolean) - Method in interface org.apache.hadoop.hbase.io.hfile.CacheableDeserializer
-
- deserialize(KeyValue) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueDeserializer
-
- deserialize(byte[]) - Static method in exception org.apache.hadoop.hbase.procedure2.RemoteProcedureException
-
Takes a series of bytes and tries to generate an RemoteProcedureException instance for it.
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.TestMasterProcedureQueue.TestTableProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called on store load to allow the user to decode the previously serialized
state.
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility.TestProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.procedure2.SequentialProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.TestWALProcedureStore.TestSequentialProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.procedure2.TestProcedureRecovery.TestStateMachineProcedure
-
- deserializeStateData(InputStream) - Method in class org.apache.hadoop.hbase.security.access.TestAccessController.TestTableDDLProcedure
-
- DEST_SERVER_NAME_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MoveRegionRequest
-
- DESTINATION_SERVER_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.CloseRegionRequest
-
- destroy() - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
-
- destroy() - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
-
- destroy() - Method in class org.apache.hadoop.hbase.http.NoCacheFilter
-
- destroy() - Method in class org.apache.hadoop.hbase.http.TestGlobalFilter.RecordingFilter
-
- destroy() - Method in class org.apache.hadoop.hbase.http.TestHttpServer.DummyServletFilter
-
- destroy() - Method in class org.apache.hadoop.hbase.http.TestPathFilter.RecordingFilter
-
- destroy() - Method in class org.apache.hadoop.hbase.http.TestServletFilter.SimpleFilter
-
- destroy() - Method in class org.apache.hadoop.hbase.rest.DummyFilter
-
- destroy() - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
-
- destroyDirectByteBuffer(ByteBuffer) - Static method in class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
DirectByteBuffers are garbage collected by using a phantom reference and a
reference queue.
- detail(String) - Method in interface org.apache.hadoop.hbase.util.HBaseFsck.ErrorReporter
-
- Dictionary - Interface in org.apache.hadoop.hbase.io.util
-
Dictionary interface
Dictionary indexes should be either bytes or shorts, only positive.
- DIFF_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.PingProtos.IncrementCountRequest
-
- DiffCompressionState() - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffCompressionState
-
- difference - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerRowSearchResult
-
fields
- DiffKeyDeltaEncoder - Class in org.apache.hadoop.hbase.io.encoding
-
Compress using:
- store size of common prefix
- save column family once, it is same within HFile
- use integer compression for key, value and prefix (7-bit encoding)
- use bits to avoid duplication key length, value length
and type if it same as previous
- store in 3 bits length of timestamp field
- allow diff in timestamp instead of actual value
Format:
- 1 byte: flag
- 1-5 bytes: key length (only if FLAG_SAME_KEY_LENGTH is not set in flag)
- 1-5 bytes: value length (only if FLAG_SAME_VALUE_LENGTH is not set in flag)
- 1-5 bytes: prefix length
- ...
- DiffKeyDeltaEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder
-
- DiffKeyDeltaEncoder.DiffCompressionState - Class in org.apache.hadoop.hbase.io.encoding
-
- DiffKeyDeltaEncoder.DiffSeekerState - Class in org.apache.hadoop.hbase.io.encoding
-
- DiffSeekerState() - Constructor for class org.apache.hadoop.hbase.io.encoding.DiffKeyDeltaEncoder.DiffSeekerState
-
- dir - Static variable in class org.apache.hadoop.hbase.regionserver.wal.TestFSHLog
-
- dir - Variable in class org.apache.hadoop.hbase.regionserver.wal.TestProtobufLog
-
- dir - Variable in class org.apache.hadoop.hbase.wal.TestWALFactory
-
- DirectMemoryUtils - Class in org.apache.hadoop.hbase.util
-
Utilities for interacting with and monitoring DirectByteBuffer allocations.
- DirectMemoryUtils() - Constructor for class org.apache.hadoop.hbase.util.DirectMemoryUtils
-
- DirFilter(FileSystem) - Constructor for class org.apache.hadoop.hbase.util.FSUtils.DirFilter
-
- disable(HTableDescriptor) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Turn off processing constraints for a given table, even if constraints have
been turned on or added.
- DISABLE_TABLE_MARK_REGIONS_OFFLINE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableState
-
DISABLE_TABLE_MARK_REGIONS_OFFLINE = 4;
- DISABLE_TABLE_POST_OPERATION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableState
-
DISABLE_TABLE_POST_OPERATION = 6;
- DISABLE_TABLE_PRE_OPERATION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableState
-
DISABLE_TABLE_PRE_OPERATION = 2;
- DISABLE_TABLE_PREPARE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableState
-
DISABLE_TABLE_PREPARE = 1;
- DISABLE_TABLE_SET_DISABLED_TABLE_STATE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableState
-
DISABLE_TABLE_SET_DISABLED_TABLE_STATE = 5;
- DISABLE_TABLE_SET_DISABLING_TABLE_STATE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DisableTableState
-
DISABLE_TABLE_SET_DISABLING_TABLE_STATE = 3;
- disableConstraint(HTableDescriptor, Class<? extends Constraint>) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
- DISABLED - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.OffPeakHours
-
- DISABLED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription.Type
-
DISABLED = 0;
- DISABLED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State
-
DISABLED = 1;
- DISABLED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
-
DISABLED = 1;
- DISABLED_ZNODE_BYTES - Static variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
- DisabledRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
-
- DisabledRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.DisabledRegionSplitPolicy
-
- DisabledTableSnapshotHandler - Class in org.apache.hadoop.hbase.master.snapshot
-
Take a snapshot of a disabled table.
- DisabledTableSnapshotHandler(HBaseProtos.SnapshotDescription, MasterServices) - Constructor for class org.apache.hadoop.hbase.master.snapshot.DisabledTableSnapshotHandler
-
- DisabledTestCheckColumn_WrongOrder() - Method in class org.apache.hadoop.hbase.regionserver.TestScanWildcardColumnTracker
-
- disableHFileBackup(String) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
Disable hfile backups for the given table.
- disableHFileBackup(byte[]) - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
Disable hfile backups for the given table.
- disableHFileBackup() - Method in class org.apache.hadoop.hbase.backup.example.ZKTableArchiveClient
-
Disable hfile backups for all tables.
- disableJSON() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
turns JSON output off, and turns on "pretty strings" for human consumption
- disablePeer(String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Stop the replication stream to the specified peer.
- disablePeer(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Stop the replication to the specified remote slave cluster.
- disablePeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- disableTable(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Disable table and wait on completion.
- disableTable(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Disable table and wait on completion.
- disableTable(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTable(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTable(TableName) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- disableTable(RpcController, MasterProtos.DisableTableRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- disableTable(TableName) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Disable an existing table
- disableTable(com.google.protobuf.RpcController, MasterProtos.DisableTableRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- disableTable(com.google.protobuf.RpcController, MasterProtos.DisableTableRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc DisableTable(.DisableTableRequest) returns (.DisableTableResponse);
- disableTable(com.google.protobuf.RpcController, MasterProtos.DisableTableRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc DisableTable(.DisableTableRequest) returns (.DisableTableResponse);
- disableTable(com.google.protobuf.RpcController, MasterProtos.DisableTableRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- disableTable(ByteBuffer, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- disableTable(ByteBuffer, <any>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- disableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- disableTable(ByteBuffer) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Disables a table (takes it off-line) If it is being served, the master
will tell the servers to stop serving it.
- disableTable() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.disableTable
-
- disableTable(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- disableTable_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- disableTable_args(ByteBuffer) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
- disableTable_args(Hbase.disableTable_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_args
-
Performs a deep copy on other.
- disableTable_call(ByteBuffer, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.disableTable_call
-
- disableTable_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- disableTable_result(IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
- disableTable_result(Hbase.disableTable_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.disableTable_result
-
Performs a deep copy on other.
- disableTableAsync(TableName) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Starts the disable of a table.
- disableTableAsync(TableName) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Starts the disable of a table.
- disableTableAsync(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- disableTableAsync(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- DisableTableHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handler to run disable of a table.
- DisableTableHandler(Server, TableName, AssignmentManager, TableLockManager, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.DisableTableHandler
-
- DisableTableProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
- DisableTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- DisableTableProcedure(MasterProcedureEnv, TableName, boolean) - Constructor for class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Constructor
- DisableTableProcedure(MasterProcedureEnv, TableName, boolean, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
Constructor
- disableTableRep(TableName) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Disable a table's replication switch.
- disableTables(String) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Disable tables matching the passed in pattern and wait on completion.
- disableTables(Pattern) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Disable tables matching the passed in pattern and wait on completion.
- disableTables(String) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Disable tables matching the passed in pattern and wait on completion.
- disableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Disable tables matching the passed in pattern and wait on completion.
- disableValues() - Method in class org.apache.hadoop.hbase.wal.WALPrettyPrinter
-
turns value output off
- DISABLING_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Table.State
-
DISABLING = 2;
- DISALLOW_WRITES_IN_RECOVERING - Static variable in class org.apache.hadoop.hbase.HConstants
-
- discardCurrentRowNode(boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- disconnect() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- disconnectSince() - Method in interface org.apache.hadoop.hbase.ipc.RpcCallContext
-
Check if the caller who made this IPC call has disconnected.
- dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
-
- dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.FifoRpcScheduler
-
- dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RpcExecutor
-
Add the request to the executor queue
- dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RpcScheduler
-
Dispatches an RPC request asynchronously.
- dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
-
- dispatch(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
-
- DispatchMergingRegionHandler - Class in org.apache.hadoop.hbase.master.handler
-
Handles MERGE regions request on master: move the regions together(on the
same regionserver) and send MERGE RPC to regionserver.
- DispatchMergingRegionHandler(MasterServices, CatalogJanitor, HRegionInfo, HRegionInfo, boolean) - Constructor for class org.apache.hadoop.hbase.master.handler.DispatchMergingRegionHandler
-
- dispatchMergingRegions(HRegionInfo, HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- dispatchMergingRegions(RpcController, MasterProtos.DispatchMergingRegionsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- dispatchMergingRegions(HRegionInfo, HRegionInfo, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Merge two regions.
- dispatchMergingRegions(com.google.protobuf.RpcController, MasterProtos.DispatchMergingRegionsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- dispatchMergingRegions(com.google.protobuf.RpcController, MasterProtos.DispatchMergingRegionsRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc DispatchMergingRegions(.DispatchMergingRegionsRequest) returns (.DispatchMergingRegionsResponse);
- dispatchMergingRegions(com.google.protobuf.RpcController, MasterProtos.DispatchMergingRegionsRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc DispatchMergingRegions(.DispatchMergingRegionsRequest) returns (.DispatchMergingRegionsResponse);
- dispatchMergingRegions(com.google.protobuf.RpcController, MasterProtos.DispatchMergingRegionsRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- displayStatistics() - Method in class org.apache.hadoop.hbase.regionserver.DataBlockEncodingTool
-
Display statistics of different compression algorithms.
- dispose() - Method in class org.apache.hadoop.hbase.security.HBaseSaslRpcClient
-
Release resources used by wrapped saslClient
- DISTRIBUTED_LOG_REPLAY_KEY - Static variable in class org.apache.hadoop.hbase.HConstants
-
Conf key that enables unflushed WAL edits directly being replayed to region servers
- DistributedHBaseCluster - Class in org.apache.hadoop.hbase
-
Manages the interactions with an already deployed distributed cluster (as opposed to
a pseudo-distributed, or mini/local cluster).
- DistributedHBaseCluster(Configuration, ClusterManager) - Constructor for class org.apache.hadoop.hbase.DistributedHBaseCluster
-
- distributedLogReplay - Variable in class org.apache.hadoop.hbase.regionserver.TestRegionReplicaFailover
-
- distributedLogReplay - Variable in class org.apache.hadoop.hbase.wal.WALSplitter
-
- divideForAvg(BigDecimal, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- divideForAvg(Double, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- divideForAvg(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- divideForAvg(S, Long) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
used for computing average of data values.
- DNS - Class in org.apache.hadoop.hbase.util
-
Wrapper around Hadoop's DNS class to hide reflection.
- DO_NOT_RETRY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.RPCProtos.ExceptionResponse
-
- doAction(BaseLoadBalancer.Cluster.Action) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster
-
- DoActionsOncePolicy - Class in org.apache.hadoop.hbase.chaos.policies
-
A policy which performs a sequence of actions deterministically.
- DoActionsOncePolicy(long, List<Action>) - Constructor for class org.apache.hadoop.hbase.chaos.policies.DoActionsOncePolicy
-
- DoActionsOncePolicy(long, Action...) - Constructor for class org.apache.hadoop.hbase.chaos.policies.DoActionsOncePolicy
-
- doAnAction() - Method in class org.apache.hadoop.hbase.MultithreadedTestUtil.RepeatingTestThread
-
- doAnAction() - Method in class org.apache.hadoop.hbase.regionserver.TestHRegionServerBulkLoad.AtomicHFileLoader
-
- doAnAction() - Method in class org.apache.hadoop.hbase.regionserver.TestHRegionServerBulkLoad.AtomicScanReader
-
- doAnAction() - Method in class org.apache.hadoop.hbase.TestAcidGuarantees.AtomicGetReader
-
- doAnAction() - Method in class org.apache.hadoop.hbase.TestAcidGuarantees.AtomicityWriter
-
- doAnAction() - Method in class org.apache.hadoop.hbase.TestAcidGuarantees.AtomicScanReader
-
- doAssert(byte[], String) - Static method in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsReplication
-
- doAsUser - Static variable in class org.apache.hadoop.hbase.thrift.HttpDoAsClient
-
- doBulkLoad(Path, HTable) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
Perform a bulk load of the given directory into the given
pre-existing table.
- doBulkLoad(Path, Admin, Table, RegionLocator) - Method in class org.apache.hadoop.hbase.mapreduce.LoadIncrementalHFiles
-
Perform a bulk load of the given directory into the given
pre-existing table.
- doCompare(CompareFilter.CompareOp, ByteArrayComparable, byte[], int, int) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
-
- doExecute(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Internal method called by the ProcedureExecutor that starts the
user-level code execute().
- doExecute(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.SequentialProcedure
-
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.HttpServer.QuotingInputFilter
-
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.lib.StaticUserWebFilter.StaticUserFilter
-
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.NoCacheFilter
-
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.TestGlobalFilter.RecordingFilter
-
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.TestHttpServer.DummyServletFilter
-
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.TestPathFilter.RecordingFilter
-
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.http.TestServletFilter.SimpleFilter
-
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.rest.DummyFilter
-
- doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.apache.hadoop.hbase.rest.filter.GzipFilter
-
- doFsck(Configuration, boolean) - Static method in class org.apache.hadoop.hbase.util.hbck.HbckTestingUtil
-
- doFsck(Configuration, boolean, TableName) - Static method in class org.apache.hadoop.hbase.util.hbck.HbckTestingUtil
-
- doFsck(Configuration, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, boolean, TableName) - Static method in class org.apache.hadoop.hbase.util.hbck.HbckTestingUtil
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.AdminAuthorizedServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.conf.ConfServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.HttpServer.StackServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.jmx.JMXJsonServlet
-
Process a GET request for the specified resource.
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.log.LogLevel.Servlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.TestHttpServer.EchoMapServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.TestHttpServer.EchoServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.TestHttpServer.HtmlContentServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.http.TestHttpServer.LongHeaderServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.master.HMaster.RedirectServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.master.MasterDumpServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.master.MasterStatusServlet
-
- doGet(Connection, Get) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- doGet(Connection, List<Get>) - Static method in class org.apache.hadoop.hbase.quotas.QuotaTableUtil
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.regionserver.RSDumpServlet
-
- doGet(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.regionserver.RSStatusServlet
-
- doHFileQuarantine(Configuration, TableName) - Static method in class org.apache.hadoop.hbase.util.hbck.HbckTestingUtil
-
Runs hbck with the -sidelineCorruptHFiles option
- doLoad(Configuration, HTableDescriptor) - Method in class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify
-
- doLoad(Configuration, HTableDescriptor) - Method in class org.apache.hadoop.hbase.test.IntegrationTestWithCellVisibilityLoadAndVerify
-
- doLoadColumnFamiliesOnDemand() - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the logical value indicating whether on-demand CF loading should be allowed.
- doLoadIncrementalHFiles(Path, TableName) - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestImportTsv
-
Verify the data described by simple_tsv
matches
simple_expected
.
- doMain(String[]) - Method in class org.apache.hadoop.hbase.util.ServerCommandLine
-
Parse and run the given command line.
- domainNamePointerToHostName(String) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Given a PTR string generated via reverse DNS lookup, return everything
except the trailing period.
- doMetrics() - Method in class org.apache.hadoop.hbase.master.HMaster
-
Emit the HMaster metrics, such as region in transition metrics.
- doMetrics() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- doMROnTableTest(HBaseTestingUtility, String, String, String[]) - Static method in class org.apache.hadoop.hbase.mapreduce.TestImportTsv
-
- doMROnTableTest(HBaseTestingUtility, String, String, String[], int) - Static method in class org.apache.hadoop.hbase.mapreduce.TestImportTsv
-
Run an ImportTsv job and perform basic validation on the results.
- doMROnTableTest(HBaseTestingUtility, String, String, String[], int) - Static method in class org.apache.hadoop.hbase.mapreduce.TestImportTSVWithTTLs
-
- doMROnTableTest(HBaseTestingUtility, String, String, String[], int) - Static method in class org.apache.hadoop.hbase.mapreduce.TestImportTSVWithVisibilityLabels
-
Run an ImportTsv job and perform basic validation on the results.
- done - Variable in class org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
-
- done() - Method in interface org.apache.hadoop.hbase.regionserver.ColumnTracker
-
- done() - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
Done when there are no more columns to match against.
- done() - Method in class org.apache.hadoop.hbase.regionserver.ScanWildcardColumnTracker
-
We can never know a-priori if we are done, so always return false.
- done() - Method in class org.apache.hadoop.hbase.regionserver.TestHRegion.FlushThread
-
- done() - Method in class org.apache.hadoop.hbase.regionserver.TestHRegion.PutThread
-
- Done(ServerName, ZooKeeperProtos.SplitLogTask.RecoveryMode) - Constructor for class org.apache.hadoop.hbase.SplitLogTask.Done
-
- done - Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- DONE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsProcedureDoneResponse
-
- DONE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsRestoreSnapshotDoneResponse
-
- DONE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.IsSnapshotDoneResponse
-
- DONE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.SplitLogTask.State
-
DONE = 3;
- doneBulkLoad(byte[], String) - Method in interface org.apache.hadoop.hbase.regionserver.Region.BulkLoadListener
-
Called after a successful HFile load
- doneWithColumn(byte[], int, int) - Method in class org.apache.hadoop.hbase.regionserver.ExplicitColumnTracker
-
This method is used to inform the column tracker that we are done with
this column.
- DoNothingChore(String, int) - Constructor for class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.DoNothingChore
-
- DoNothingChore(String, Stoppable, int) - Constructor for class org.apache.hadoop.hbase.TestChoreService.ScheduledChoreSamples.DoNothingChore
-
- DoNotRetryIOException - Exception in org.apache.hadoop.hbase
-
Subclass if exception is not meant to be retried: e.g.
- DoNotRetryIOException() - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
default constructor
- DoNotRetryIOException(String) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DoNotRetryIOException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DoNotRetryIOException(Throwable) - Constructor for exception org.apache.hadoop.hbase.DoNotRetryIOException
-
- DoNotRetryRegionException - Exception in org.apache.hadoop.hbase.client
-
Similar to RegionException, but disables retries.
- DoNotRetryRegionException() - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
-
- DoNotRetryRegionException(String) - Constructor for exception org.apache.hadoop.hbase.client.DoNotRetryRegionException
-
- DONT_BREAK_LINES - Static variable in class org.apache.hadoop.hbase.util.Base64
-
Don't break lines when encoding (violates strict Base64 specification)
- DONT_FILL_HEADER - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
- doPost(HttpServletRequest, HttpServletResponse) - Method in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
-
- doReadBenchmark() - Method in class org.apache.hadoop.hbase.client.TestResult
-
- doRealSeek(KeyValueScanner, Cell, boolean) - Static method in class org.apache.hadoop.hbase.regionserver.NonLazyKeyValueScanner
-
- doRegionCompactionPrep() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- doRegionCompactionPrep() - Method in class org.apache.hadoop.hbase.TestIOFencing.BlockCompactionsInPrepRegion
-
- doRollback(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Internal method called by the ProcedureExecutor that starts the
user-level code rollback().
- doRollback(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.SequentialProcedure
-
- doScan(HRegion, Scan, List<Cell>) - Static method in class org.apache.hadoop.hbase.coprocessor.TestRowProcessorEndpoint.RowProcessorEndpoint
-
- doSetup(Context) - Method in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
-
Handles common parameter initialization that a subclass might want to leverage.
- doSetup(Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
-
Handles common parameter initialization that a subclass might want to leverage.
- doSetup(Context) - Method in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
-
Handles common parameter initialization that a subclass might want to leverage.
- doSmokeTest(FileSystem, Path, String) - Static method in class org.apache.hadoop.hbase.util.CompressionTest
-
- doStart() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- doStart() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- doStart() - Method in class org.apache.hadoop.hbase.replication.TestReplicationEndpoint.ReplicationEndpointForTest
-
- doStaticMain(String[]) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
Call this from the concrete tool class's main function.
- doStop() - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- doStop() - Method in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
-
- doStop() - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint
-
- doStop() - Method in class org.apache.hadoop.hbase.replication.TestReplicationEndpoint.ReplicationEndpointForTest
-
- doTest(Class<?>, boolean) - Method in class org.apache.hadoop.hbase.TestIOFencing
-
- doTestAppend() - Static method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
Appends the value to a cell and checks that the cell value is updated properly.
- doTestCheckAndPut() - Static method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
Check that checkAndPut fails if the cell does not exist, then put in the cell, then check that
the checkAndPut succeeds.
- doTestDelete(HBaseTestCase.Incommon, HBaseTestCase.FlushCache) - Static method in class org.apache.hadoop.hbase.TimestampTestBase
-
- doTestDelete_AndPostInsert(Delete) - Method in class org.apache.hadoop.hbase.regionserver.TestHRegion
-
- doTestFilterRegistration() - Method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
- doTestGetRegionInfo() - Method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
- doTestGetRegionInfo(Hbase.Iface) - Static method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
- doTestGetStorageClusterVersionJSON() - Method in class org.apache.hadoop.hbase.rest.TestVersionResource
-
- doTestGetTableRegions() - Method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
For HBASE-2556
Tests for GetTableRegions
- doTestGetTableRegions(Hbase.Iface) - Static method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
- doTestIncrements() - Method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
- doTestIncrements(ThriftServerRunner.HBaseHandler) - Static method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
- doTestTableCreateDrop() - Method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
Tests for creating, enabling, disabling, and deleting tables.
- doTestTableCreateDrop(Hbase.Iface) - Static method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
- doTestTableMutations() - Method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
Tests adding a series of Mutations and BatchMutations, including a
delete mutation.
- doTestTableMutations(Hbase.Iface) - Static method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
- doTestTableScanners() - Method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
Tests the four different scanner-opening methods (with and without
a stoprow, with and without a timestamp).
- doTestTableTimestampsAndColumns() - Method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
Similar to testTableMutations(), except Mutations are applied with
specific timestamps and data retrieval uses these timestamps to
extract specific versions of data.
- doTestThriftMetrics() - Method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
Tests if the metrics for thrift handler work correctly
- doTestTimestampScanning(HBaseTestCase.Incommon, HBaseTestCase.FlushCache) - Static method in class org.apache.hadoop.hbase.TimestampTestBase
-
- doTestWithMapReduce(HBaseTestingUtility, TableName, String, byte[], byte[], Path, int, int, boolean) - Static method in class org.apache.hadoop.hbase.mapred.TestTableSnapshotInputFormat
-
- doTestWithMapReduce(HBaseTestingUtility, TableName, String, byte[], byte[], Path, int, int, boolean) - Static method in class org.apache.hadoop.hbase.mapreduce.TestTableSnapshotInputFormat
-
- DOUBLE_MSG_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.DoubleMsg
-
- DoubleColumnInterpreter - Class in org.apache.hadoop.hbase.client.coprocessor
-
a concrete column interpreter implementation.
- DoubleColumnInterpreter() - Constructor for class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- doVerify(Configuration, HTableDescriptor) - Method in class org.apache.hadoop.hbase.test.IntegrationTestLoadAndVerify
-
- doVerify(Configuration, HTableDescriptor) - Method in class org.apache.hadoop.hbase.test.IntegrationTestWithCellVisibilityLoadAndVerify
-
- doWork() - Method in class org.apache.hadoop.hbase.chaos.util.ChaosMonkeyRunner
-
- doWork() - Method in class org.apache.hadoop.hbase.IntegrationTestBase
-
- doWork() - Method in class org.apache.hadoop.hbase.IntegrationTestsDriver
-
- doWork() - Method in class org.apache.hadoop.hbase.MultithreadedTestUtil.RepeatingTestThread
-
- doWork() - Method in class org.apache.hadoop.hbase.MultithreadedTestUtil.TestThread
-
- doWork() - Method in class org.apache.hadoop.hbase.ScanPerformanceEvaluation
-
- doWork() - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
-
- doWork() - Method in class org.apache.hadoop.hbase.StripeCompactionsPerformanceEvaluation
-
- doWork() - Method in class org.apache.hadoop.hbase.test.IntegrationTestZKAndFSPermissions
-
- doWork() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
The "main function" of the tool
- doWork() - Method in class org.apache.hadoop.hbase.util.LoadTestTool
-
- doWork() - Method in class org.apache.hadoop.hbase.util.RestartMetaTest
-
- DrainBarrier - Class in org.apache.hadoop.hbase.util
-
A simple barrier that can be used by classes that need to wait for some operations to
finish before stopping/closing/etc.
- DrainBarrier() - Constructor for class org.apache.hadoop.hbase.util.DrainBarrier
-
- DrainingServerTracker - Class in org.apache.hadoop.hbase.zookeeper
-
Tracks the list of draining region servers via ZK.
- DrainingServerTracker(ZooKeeperWatcher, Abortable, ServerManager) - Constructor for class org.apache.hadoop.hbase.zookeeper.DrainingServerTracker
-
- drainingZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- drainInputStreamToBuffer(InputStream) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Copy from the InputStream to a new heap ByteBuffer until the InputStream is exhausted.
- drainTo(Collection<? super Runnable>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- drainTo(Collection<? super Runnable>, int) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- drainTo(Collection<T>) - Method in class org.apache.hadoop.hbase.util.BoundedConcurrentLinkedQueue
-
- drainTo(Collection<? super E>) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- drainTo(Collection<? super E>, int) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue
-
- drainTo(Collection<? super E>) - Method in class org.apache.hadoop.hbase.util.ConstantDelayQueue
-
- drainTo(Collection<? super E>, int) - Method in class org.apache.hadoop.hbase.util.ConstantDelayQueue
-
- Driver - Class in org.apache.hadoop.hbase.mapred
-
Driver for hbase mapreduce jobs.
- Driver() - Constructor for class org.apache.hadoop.hbase.mapred.Driver
-
- Driver - Class in org.apache.hadoop.hbase.mapreduce
-
Driver for hbase mapreduce jobs.
- Driver() - Constructor for class org.apache.hadoop.hbase.mapreduce.Driver
-
- DROP_DEPENDENT_COLUMN_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.DependentColumnFilter
-
- dropDependentColumn - Variable in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- dropDependentColumn() - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
-
- DroppedSnapshotException - Exception in org.apache.hadoop.hbase
-
Thrown during flush if the possibility snapshot content was not properly
persisted into store files.
- DroppedSnapshotException(String) - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
-
- DroppedSnapshotException() - Constructor for exception org.apache.hadoop.hbase.DroppedSnapshotException
-
default constructor
- dropTestTables(Hbase.Iface) - Static method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
- dummyCall(com.google.protobuf.RpcController, DummyRegionServerEndpointProtos.DummyRequest) - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyService.BlockingInterface
-
- dummyCall(com.google.protobuf.RpcController, DummyRegionServerEndpointProtos.DummyRequest, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyService
-
rpc dummyCall(.DummyRequest) returns (.DummyResponse);
- dummyCall(com.google.protobuf.RpcController, DummyRegionServerEndpointProtos.DummyRequest, <any>) - Method in interface org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyService.Interface
-
rpc dummyCall(.DummyRequest) returns (.DummyResponse);
- dummyCall(com.google.protobuf.RpcController, DummyRegionServerEndpointProtos.DummyRequest, <any>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyService.Stub
-
- DummyCompactionPolicy(Configuration, StoreConfigInformation) - Constructor for class org.apache.hadoop.hbase.regionserver.TestDefaultStoreEngine.DummyCompactionPolicy
-
- DummyCompactor(Configuration, Store) - Constructor for class org.apache.hadoop.hbase.regionserver.TestDefaultStoreEngine.DummyCompactor
-
- DummyFilter - Class in org.apache.hadoop.hbase.rest
-
- DummyFilter() - Constructor for class org.apache.hadoop.hbase.rest.DummyFilter
-
- DummyFilterInitializer() - Constructor for class org.apache.hadoop.hbase.http.TestHttpServer.DummyFilterInitializer
-
- DummyMaster(ZooKeeperWatcher, ServerName) - Constructor for class org.apache.hadoop.hbase.master.TestActiveMasterManager.DummyMaster
-
- DummyRegionServerEndpointProtos - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- DummyRegionServerEndpointProtos.DummyRequest - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type DummyRequest
- DummyRegionServerEndpointProtos.DummyRequest.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type DummyRequest
- DummyRegionServerEndpointProtos.DummyRequestOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- DummyRegionServerEndpointProtos.DummyResponse - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type DummyResponse
- DummyRegionServerEndpointProtos.DummyResponse.Builder - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf type DummyResponse
- DummyRegionServerEndpointProtos.DummyResponseOrBuilder - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- DummyRegionServerEndpointProtos.DummyService - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
Protobuf service DummyService
- DummyRegionServerEndpointProtos.DummyService.BlockingInterface - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- DummyRegionServerEndpointProtos.DummyService.Interface - Interface in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- DummyRegionServerEndpointProtos.DummyService.Stub - Class in org.apache.hadoop.hbase.coprocessor.protobuf.generated
-
- DummyService() - Constructor for class org.apache.hadoop.hbase.coprocessor.protobuf.generated.DummyRegionServerEndpointProtos.DummyService
-
- DummyServletFilter() - Constructor for class org.apache.hadoop.hbase.http.TestHttpServer.DummyServletFilter
-
- DummyStoreEngine() - Constructor for class org.apache.hadoop.hbase.regionserver.TestStore.DummyStoreEngine
-
- DummyStoreFlusher(Configuration, Store) - Constructor for class org.apache.hadoop.hbase.regionserver.TestDefaultStoreEngine.DummyStoreFlusher
-
- DummyWALActionsListener() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.TestWALActionsListener.DummyWALActionsListener
-
- dump() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker.BitSetNode
-
- dump() - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureStoreTracker
-
- dump() - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
-
- dump(ZooKeeperWatcher) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
- dumpAllBeans() - Static method in class org.apache.hadoop.hbase.util.JSONBean
-
Dump out all registered mbeans as json on System.out.
- dumpAsText(PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.TaskMonitor
-
- DumpClusterStatusAction - Class in org.apache.hadoop.hbase.chaos.actions
-
Action to dump the cluster status.
- DumpClusterStatusAction() - Constructor for class org.apache.hadoop.hbase.chaos.actions.DumpClusterStatusAction
-
- dumpExecutors(ExecutorService, PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- dumpOverlapProblems(<any>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- dumpQueue() - Method in class org.apache.hadoop.hbase.regionserver.CompactSplitThread
-
- dumpQueue(HRegionServer, PrintWriter) - Static method in class org.apache.hadoop.hbase.regionserver.RSDumpServlet
-
- dumpRegionServerMetrics() - Static method in class org.apache.hadoop.hbase.util.JSONBean
-
Dump out a subset of regionserver mbeans only, not all of them, as json on System.out.
- dumpSidelinedRegions(Map<Path, HBaseFsck.HbckInfo>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
-
- dumpTailOfLogs(PrintWriter, long) - Static method in class org.apache.hadoop.hbase.monitoring.LogMonitoring
-
- dumpTo(Writer, String) - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorStatus
-
Dump a textual representation of the executor's status
to the given writer.
- dumpTo(PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
-
Dump the contents of the buffer to the given stream.
- dumpVersionInfo(PrintWriter) - Method in class org.apache.hadoop.hbase.monitoring.StateDumpServlet
-
- Durability - Enum in org.apache.hadoop.hbase.client
-
Enum describing the durability guarantees for tables and
Mutation
s
Note that the items must be sorted in order of increasing durability
- durability - Variable in class org.apache.hadoop.hbase.client.Mutation
-
- DURABILITY - Static variable in class org.apache.hadoop.hbase.HTableDescriptor
-
- durability - Variable in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- durability - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- durability - Variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- durability - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- DURABILITY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- duration - Variable in class org.apache.hadoop.hbase.PerformanceEvaluation.RunResult
-
- DynamicClassLoader - Class in org.apache.hadoop.hbase.util
-
This is a class loader that can load classes dynamically from new
jar files under a configured folder.
- DynamicClassLoader(Configuration, ClassLoader) - Constructor for class org.apache.hadoop.hbase.util.DynamicClassLoader
-
Creates a DynamicClassLoader that can load classes dynamically
from jar files under a specific folder.
- DynamicMetricsRegistry - Class in org.apache.hadoop.metrics2.lib
-
An optional metrics registry class for creating and maintaining a
collection of MetricsMutables, making writing metrics source easier.
- DynamicMetricsRegistry(String) - Constructor for class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Construct the registry with a record name
- DynamicMetricsRegistry(MetricsInfo) - Constructor for class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
-
Construct the registry with a metadata object