Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.filter |
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next() . |
org.apache.hadoop.hbase.migration | |
org.apache.hadoop.hbase.protobuf |
Holds classes generated from protobuf
src/main/protobuf definition files. |
org.apache.hadoop.hbase.replication |
Multi Cluster Replication
|
org.apache.hadoop.hbase.security.access | |
org.apache.hadoop.hbase.security.visibility | |
org.apache.hadoop.hbase.util | |
org.apache.hadoop.hbase.zookeeper |
Modifier and Type | Method and Description |
---|---|
static SplitLogTask |
SplitLogTask.parseFrom(byte[] data) |
static ServerName |
ServerName.parseFrom(byte[] data)
Get a ServerName from the passed in data bytes.
|
static RegionTransition |
RegionTransition.parseFrom(byte[] data) |
static HTableDescriptor |
HTableDescriptor.parseFrom(byte[] bytes) |
static HRegionInfo |
HRegionInfo.parseFrom(byte[] bytes) |
static HColumnDescriptor |
HColumnDescriptor.parseFrom(byte[] bytes) |
static ClusterId |
ClusterId.parseFrom(byte[] bytes) |
static HRegionInfo |
HRegionInfo.parseFrom(byte[] bytes,
int offset,
int len) |
Modifier and Type | Method and Description |
---|---|
Authorizations |
Query.getAuthorizations() |
CellVisibility |
Mutation.getCellVisibility() |
Modifier and Type | Method and Description |
---|---|
static WhileMatchFilter |
WhileMatchFilter.parseFrom(byte[] pbBytes) |
static ValueFilter |
ValueFilter.parseFrom(byte[] pbBytes) |
static TimestampsFilter |
TimestampsFilter.parseFrom(byte[] pbBytes) |
static SubstringComparator |
SubstringComparator.parseFrom(byte[] pbBytes) |
static SkipFilter |
SkipFilter.parseFrom(byte[] pbBytes) |
static SingleColumnValueFilter |
SingleColumnValueFilter.parseFrom(byte[] pbBytes) |
static SingleColumnValueExcludeFilter |
SingleColumnValueExcludeFilter.parseFrom(byte[] pbBytes) |
static RowFilter |
RowFilter.parseFrom(byte[] pbBytes) |
static RegexStringComparator |
RegexStringComparator.parseFrom(byte[] pbBytes) |
static RandomRowFilter |
RandomRowFilter.parseFrom(byte[] pbBytes) |
static QualifierFilter |
QualifierFilter.parseFrom(byte[] pbBytes) |
static PrefixFilter |
PrefixFilter.parseFrom(byte[] pbBytes) |
static PageFilter |
PageFilter.parseFrom(byte[] pbBytes) |
static NullComparator |
NullComparator.parseFrom(byte[] pbBytes) |
static MultipleColumnPrefixFilter |
MultipleColumnPrefixFilter.parseFrom(byte[] pbBytes) |
static MultiRowRangeFilter |
MultiRowRangeFilter.parseFrom(byte[] pbBytes) |
static LongComparator |
LongComparator.parseFrom(byte[] pbBytes) |
static KeyOnlyFilter |
KeyOnlyFilter.parseFrom(byte[] pbBytes) |
static InclusiveStopFilter |
InclusiveStopFilter.parseFrom(byte[] pbBytes) |
static FuzzyRowFilter |
FuzzyRowFilter.parseFrom(byte[] pbBytes) |
static FirstKeyValueMatchingQualifiersFilter |
FirstKeyValueMatchingQualifiersFilter.parseFrom(byte[] pbBytes) |
static FirstKeyOnlyFilter |
FirstKeyOnlyFilter.parseFrom(byte[] pbBytes) |
static FilterWrapper |
FilterWrapper.parseFrom(byte[] pbBytes) |
static FilterList |
FilterList.parseFrom(byte[] pbBytes) |
static Filter |
Filter.parseFrom(byte[] pbBytes)
Concrete implementers can signal a failure condition in their code by throwing an
IOException . |
static FamilyFilter |
FamilyFilter.parseFrom(byte[] pbBytes) |
static DependentColumnFilter |
DependentColumnFilter.parseFrom(byte[] pbBytes) |
static ColumnRangeFilter |
ColumnRangeFilter.parseFrom(byte[] pbBytes) |
static ColumnPrefixFilter |
ColumnPrefixFilter.parseFrom(byte[] pbBytes) |
static ColumnPaginationFilter |
ColumnPaginationFilter.parseFrom(byte[] pbBytes) |
static ColumnCountGetFilter |
ColumnCountGetFilter.parseFrom(byte[] pbBytes) |
static ByteArrayComparable |
ByteArrayComparable.parseFrom(byte[] pbBytes) |
static BitComparator |
BitComparator.parseFrom(byte[] pbBytes) |
static BinaryPrefixComparator |
BinaryPrefixComparator.parseFrom(byte[] pbBytes) |
static BinaryComparator |
BinaryComparator.parseFrom(byte[] pbBytes) |
Modifier and Type | Method and Description |
---|---|
void |
NamespaceUpgrade.upgradeTableDirs() |
Modifier and Type | Method and Description |
---|---|
static MasterProtos.DispatchMergingRegionsRequest |
RequestConverter.buildDispatchMergingRegionsRequest(byte[] encodedNameOfRegionA,
byte[] encodedNameOfRegionB,
boolean forcible) |
static MasterProtos.MoveRegionRequest |
RequestConverter.buildMoveRegionRequest(byte[] encodedRegionName,
byte[] destServerName)
Create a protocol buffer MoveRegionRequest
|
static void |
ProtobufUtil.expectPBMagicPrefix(byte[] bytes) |
static Authorizations |
ProtobufUtil.toAuthorizations(byte[] protoBytes)
Convert a protocol buffer Authorizations bytes to a client Authorizations
|
static CellVisibility |
ProtobufUtil.toCellVisibility(byte[] protoBytes)
Convert a protocol buffer CellVisibility bytes to a client CellVisibility
|
Modifier and Type | Method and Description |
---|---|
static boolean |
ReplicationPeerZKImpl.isStateEnabled(byte[] bytes)
Parse the raw data from ZK to get a peer's state
|
Modifier and Type | Method and Description |
---|---|
static com.google.common.collect.ListMultimap<String,TablePermission> |
AccessControlLists.readPermissions(byte[] data,
org.apache.hadoop.conf.Configuration conf)
Reads a set of permissions as
Writable instances
from the input stream. |
Modifier and Type | Method and Description |
---|---|
static List<VisibilityLabelsProtos.VisibilityLabel> |
VisibilityUtils.readLabelsFromZKData(byte[] data)
Reads back from the zookeeper.
|
static VisibilityLabelsProtos.MultiUserAuthorizations |
VisibilityUtils.readUserAuthsFromZKData(byte[] data)
Reads back User auth data written to zookeeper.
|
Modifier and Type | Method and Description |
---|---|
static void |
FSUtils.checkVersion(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootdir,
boolean message)
Verifies current version of file system
|
static void |
FSUtils.checkVersion(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootdir,
boolean message,
int wait,
int retries)
Verifies current version of file system
|
static String |
FSUtils.getVersion(org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootdir)
Verifies current version of file system
|
Modifier and Type | Method and Description |
---|---|
static org.apache.zookeeper.KeeperException |
ZKUtil.convert(DeserializationException e)
Convert a
DeserializationException to a more palatable KeeperException . |
Modifier and Type | Method and Description |
---|---|
static ZooKeeperProtos.Master |
MasterAddressTracker.parse(byte[] data) |
static ClusterStatusProtos.RegionStoreSequenceIds |
ZKUtil.parseRegionStoreSequenceIds(byte[] bytes) |
static long |
ZKUtil.parseWALPositionFrom(byte[] bytes) |
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.