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

K

K - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'K'
KEEP_DELETED_CELLS - Static variable in class org.apache.hadoop.hbase.HColumnDescriptor
 
KEEP_REGION_LOADS - Static variable in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
KEEP_SEQID_PERIOD - Static variable in class org.apache.hadoop.hbase.HConstants
Parameter name for # days to keep MVCC values during a major compaction
KeepDeletedCells - Enum in org.apache.hadoop.hbase
Ways to keep cells marked for delete around.
keeperException(KeeperException) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
Handles KeeperExceptions in client calls.
keepHFiles(String) - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
Determine if the given table should or should not allow its hfiles to be deleted
keepSeqIdPeriod - Variable in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
specify how many days to keep MVCC values during major compaction
key - Variable in class org.apache.hadoop.hbase.regionserver.LruHashMap.Entry
The key
KEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
KEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationKey
 
KEY_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row
 
KEY_FOR_HOSTNAME_SEEN_BY_MASTER - Static variable in class org.apache.hadoop.hbase.HConstants
 
KEY_ID_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
KEY_INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
 
KEY_LENGTH - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
KEY_LENGTH_BITS - Static variable in class org.apache.hadoop.hbase.io.crypto.aes.AES
 
KEY_LENGTH_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
Size of the key length field in bytes
KEY_MAX_REGIONS - Static variable in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
KEY_MAX_TABLES - Static variable in class org.apache.hadoop.hbase.master.TableNamespaceManager
 
KEY_ONE - Static variable in class org.apache.hadoop.hbase.replication.TestReplicationStateBasic
 
KEY_PREFIX - Static variable in class org.apache.hadoop.hbase.trace.HBaseHTraceConfiguration
 
KEY_TWO - Static variable in class org.apache.hadoop.hbase.replication.TestReplicationStateBasic
 
KEY_TYPE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.CellProtos.KeyValue
 
KEY_VALUE_BYTES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
 
KEY_VALUE_LEN_SIZE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileReaderV2
The size of a (key length, value length) tuple that prefixes each entry in a data block.
KEY_VALUE_VER_WITH_MEMSTORE - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
Version for KeyValue which includes memstore timestamp
KEY_VALUE_VERSION - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
KeyValue version in FileInfo
keyCount - Variable in class org.apache.hadoop.hbase.util.ByteBloomFilter
Keys currently in the bloom
keyId - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
keyLength(Cell) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Returns number of bytes this cell's key part would have been used if serialized as in KeyValue.
KeyLocker<K> - Class in org.apache.hadoop.hbase.util
A utility class to manage a set of locks.
KeyLocker() - Constructor for class org.apache.hadoop.hbase.util.KeyLocker
 
keyOnly(byte[]) - Static method in class org.apache.hadoop.hbase.util.HBaseFsck
 
KeyOnlyFilter - Class in org.apache.hadoop.hbase.filter
A filter that will only return the key component of each KV (the value will be rewritten as empty).
KeyOnlyFilter() - Constructor for class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
KeyOnlyFilter(boolean) - Constructor for class org.apache.hadoop.hbase.filter.KeyOnlyFilter
 
KeyOnlyKeyValue() - Constructor for class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
KeyOnlyKeyValue(byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
KeyOnlyKeyValue(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
 
keyPassword(String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
KeyPrefixRegionSplitPolicy - Class in org.apache.hadoop.hbase.regionserver
A custom RegionSplitPolicy implementing a SplitPolicy that groups rows by a prefix of the row-key This ensures that a region is not split "inside" a prefix of a row key.
KeyPrefixRegionSplitPolicy() - Constructor for class org.apache.hadoop.hbase.regionserver.KeyPrefixRegionSplitPolicy
 
KeyProvider - Interface in org.apache.hadoop.hbase.io.crypto
KeyProvider is a interface to abstract the different methods of retrieving key material from key storage such as Java key store.
KeyProviderForTesting - Class in org.apache.hadoop.hbase.io.crypto
Return a fixed secret key for AES for testing.
KeyProviderForTesting() - Constructor for class org.apache.hadoop.hbase.io.crypto.KeyProviderForTesting
 
KeyRange - Interface in org.apache.hadoop.hbase.util
A key range use in split coverage.
KEYS - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
 
KEYS_FOR_HBA_CREATE_TABLE - Static variable in class org.apache.hadoop.hbase.HBaseTestingUtility
 
keySet() - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
 
keySet() - Method in class org.apache.hadoop.hbase.regionserver.LruHashMap
Intentionally unimplemented.
keySet() - Method in class org.apache.hadoop.hbase.util.PoolMap
 
keyStore(String, String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
KeyStoreKeyProvider - Class in org.apache.hadoop.hbase.io.crypto
A basic KeyProvider that can resolve keys from a protected KeyStore file on the local filesystem.
KeyStoreKeyProvider() - Constructor for class org.apache.hadoop.hbase.io.crypto.KeyStoreKeyProvider
 
KeyStoreTestUtil - Class in org.apache.hadoop.hbase.http.ssl
 
KeyStoreTestUtil() - Constructor for class org.apache.hadoop.hbase.http.ssl.KeyStoreTestUtil
 
keyToString(byte[]) - Static method in class org.apache.hadoop.hbase.KeyValue
 
keyToString(byte[], int, int) - Static method in class org.apache.hadoop.hbase.KeyValue
Use for logging.
KeyValue - Class in org.apache.hadoop.hbase
An HBase Key/Value.
KeyValue() - Constructor for class org.apache.hadoop.hbase.KeyValue
Writable Constructor -- DO NOT USE
KeyValue(byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue from the start of the specified byte array.
KeyValue(byte[], int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue from the specified byte array and offset.
KeyValue(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue from the specified byte array, starting at offset, and for length length.
KeyValue(byte[], int, int, long) - Constructor for class org.apache.hadoop.hbase.KeyValue
Creates a KeyValue from the specified byte array, starting at offset, and for length length.
KeyValue(byte[], long) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with null value.
KeyValue(byte[], long, KeyValue.Type) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with null value.
KeyValue(byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with null value.
KeyValue(byte[], byte[], byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with null value.
KeyValue(byte[], byte[], byte[], long, KeyValue.Type) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, byte[], Tag[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, byte[], List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, KeyValue.Type, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, KeyValue.Type, byte[], List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], long, KeyValue.Type, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], int, int, long, KeyValue.Type, byte[], int, int, List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], byte[], byte[], int, int, long, KeyValue.Type, byte[], int, int, byte[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
 
KeyValue(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], int, byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, Tag[]) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs KeyValue structure filled with specified values.
KeyValue(byte[], int, int, byte[], int, int, byte[], int, int, long, KeyValue.Type, byte[], int, int, byte[], int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
 
KeyValue(int, int, int, long, KeyValue.Type, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs an empty KeyValue structure, with specified sizes.
KeyValue(int, int, int, long, KeyValue.Type, int, int) - Constructor for class org.apache.hadoop.hbase.KeyValue
Constructs an empty KeyValue structure, with specified sizes.
KeyValue(byte[], int, int, byte[], int, int, ByteBuffer, long, KeyValue.Type, ByteBuffer, List<Tag>) - Constructor for class org.apache.hadoop.hbase.KeyValue
 
KeyValue(Cell) - Constructor for class org.apache.hadoop.hbase.KeyValue
 
KeyValue.KeyOnlyKeyValue - Class in org.apache.hadoop.hbase
A simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly used in places where we need to compare two cells.
KeyValue.KVComparator - Class in org.apache.hadoop.hbase
Compare KeyValues.
KeyValue.MetaComparator - Class in org.apache.hadoop.hbase
A KeyValue.KVComparator for hbase:meta catalog table KeyValues.
KeyValue.RawBytesComparator - Class in org.apache.hadoop.hbase
This is a TEST only Comparator used in TestSeekTo and TestReseekTo.
KeyValue.RowOnlyComparator - Class in org.apache.hadoop.hbase
Comparator that compares row component only of a KeyValue.
KeyValue.SamePrefixComparator<T> - Interface in org.apache.hadoop.hbase
Avoids redundant comparisons for better performance.
KeyValue.Type - Enum in org.apache.hadoop.hbase
Key type.
KEYVALUE_INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
 
KEYVALUE_WITH_TAGS_INFRASTRUCTURE_SIZE - Static variable in class org.apache.hadoop.hbase.KeyValue
 
KeyValueCodec - Class in org.apache.hadoop.hbase.codec
Codec that does KeyValue version 1 serialization.
KeyValueCodec() - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodec
 
KeyValueCodec.KeyValueDecoder - Class in org.apache.hadoop.hbase.codec
 
KeyValueCodec.KeyValueEncoder - Class in org.apache.hadoop.hbase.codec
 
KeyValueCodecWithTags - Class in org.apache.hadoop.hbase.codec
Codec that does KeyValue version 1 serialization with serializing tags also.
KeyValueCodecWithTags() - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags
 
KeyValueCodecWithTags.KeyValueDecoder - Class in org.apache.hadoop.hbase.codec
 
KeyValueCodecWithTags.KeyValueEncoder - Class in org.apache.hadoop.hbase.codec
 
KeyValueDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueDecoder
 
KeyValueDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueDecoder
 
KeyValueDeserializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueDeserializer
 
KeyValueEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodec.KeyValueEncoder
 
KeyValueEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.KeyValueCodecWithTags.KeyValueEncoder
 
KeyValueHeap - Class in org.apache.hadoop.hbase.regionserver
Implements a heap merge across any number of KeyValueScanners.
KeyValueHeap(List<? extends KeyValueScanner>, KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.KeyValueHeap
Constructor.
KeyValueHeap.KVScannerComparator - Class in org.apache.hadoop.hbase.regionserver
 
KeyValueImporter() - Constructor for class org.apache.hadoop.hbase.mapreduce.Import.KeyValueImporter
 
KeyValueScanFixture - Class in org.apache.hadoop.hbase.regionserver
A fixture that implements and presents a KeyValueScanner.
KeyValueScanFixture(KeyValue.KVComparator, KeyValue...) - Constructor for class org.apache.hadoop.hbase.regionserver.KeyValueScanFixture
 
KeyValueScanner - Interface in org.apache.hadoop.hbase.regionserver
Scanner that returns the next KeyValue.
KeyValueSerialization - Class in org.apache.hadoop.hbase.mapreduce
 
KeyValueSerialization() - Constructor for class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
 
KeyValueSerialization.KeyValueDeserializer - Class in org.apache.hadoop.hbase.mapreduce
 
KeyValueSerialization.KeyValueSerializer - Class in org.apache.hadoop.hbase.mapreduce
 
KeyValueSerializer() - Constructor for class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
 
KeyValueSortReducer - Class in org.apache.hadoop.hbase.mapreduce
Emits sorted KeyValues.
KeyValueSortReducer() - Constructor for class org.apache.hadoop.hbase.mapreduce.KeyValueSortReducer
 
KeyValueTestUtil - Class in org.apache.hadoop.hbase
 
KeyValueTestUtil() - Constructor for class org.apache.hadoop.hbase.KeyValueTestUtil
 
KeyValueUtil - Class in org.apache.hadoop.hbase
static convenience methods for dealing with KeyValues and collections of KeyValues
KeyValueUtil() - Constructor for class org.apache.hadoop.hbase.KeyValueUtil
 
kill(ClusterManager.ServiceType, String, int) - Method in class org.apache.hadoop.hbase.HBaseClusterManager
 
kill() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster.MiniHBaseClusterRegionServer
 
kill() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
kill(ClusterManager.ServiceType, String, int) - Method in class org.apache.hadoop.hbase.RESTApiClusterManager
 
KILL_MASTER_TIMEOUT_DEFAULT - Static variable in class org.apache.hadoop.hbase.chaos.actions.Action
 
KILL_MASTER_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.chaos.actions.Action
 
KILL_RS_TIMEOUT_DEFAULT - Static variable in class org.apache.hadoop.hbase.chaos.actions.Action
 
KILL_RS_TIMEOUT_KEY - Static variable in class org.apache.hadoop.hbase.chaos.actions.Action
 
killAll() - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
Do a simulated kill all masters and regionservers.
killBeforeStoreUpdate - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.Testing
 
killCurrentActiveZooKeeperServer() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
killMaster(ServerName) - Method in class org.apache.hadoop.hbase.chaos.actions.Action
 
killMaster(ServerName) - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
 
killMaster(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Kills the master process if this is a distributed cluster, otherwise, this causes master to exit doing basic clean up only.
killMaster(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
 
killMaster() - Method in class org.apache.hadoop.hbase.util.ProcessBasedLocalHBaseCluster
 
killMasterTimeout - Variable in class org.apache.hadoop.hbase.chaos.actions.Action
 
killOneBackupZooKeeperServer() - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
Kill one back up ZK servers
killOneMasterRS() - Method in class org.apache.hadoop.hbase.replication.TestReplicationKillMasterRS
 
killOneSlaveRS() - Method in class org.apache.hadoop.hbase.replication.TestReplicationKillSlaveRS
 
killRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.DistributedHBaseCluster
 
killRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.HBaseCluster
Kills the region server process if this is a distributed cluster, otherwise this causes the region server to exit doing basic clean up only.
killRegionServer(ServerName) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
 
killRegionServer(int) - Method in class org.apache.hadoop.hbase.util.ProcessBasedLocalHBaseCluster
 
killRs(ServerName) - Method in class org.apache.hadoop.hbase.chaos.actions.Action
 
killRsTimeout - Variable in class org.apache.hadoop.hbase.chaos.actions.Action
 
KIND_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.TokenIdentifier
 
KIND_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.DelegationToken
 
KRB_KEYTAB_FILE - Static variable in class org.apache.hadoop.hbase.security.HBaseKerberosUtils
 
KRB_PRINCIPAL - Static variable in class org.apache.hadoop.hbase.security.HBaseKerberosUtils
 
KVComparator() - Constructor for class org.apache.hadoop.hbase.KeyValue.KVComparator
 
kvComparator - Variable in class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
 
kvCreator - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
kvGenerator - Variable in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
 
kvs - Variable in class org.apache.hadoop.hbase.regionserver.TestStripeCompactor.StoreFileWritersCapture.Writer
 
KVScannerComparator(KeyValue.KVComparator) - Constructor for class org.apache.hadoop.hbase.regionserver.KeyValueHeap.KVScannerComparator
Constructor
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
Skip navigation links
Hortonworks Data Platform 2.4.0