Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.coordination | |
org.apache.hadoop.hbase.filter |
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next() . |
org.apache.hadoop.hbase.master | |
org.apache.hadoop.hbase.migration | |
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 HTableDescriptor |
HTableDescriptor.parseFrom(byte[] bytes) |
static RegionTransition |
RegionTransition.parseFrom(byte[] data) |
static HColumnDescriptor |
HColumnDescriptor.parseFrom(byte[] bytes) |
static HRegionInfo |
HRegionInfo.parseFrom(byte[] bytes) |
static ServerName |
ServerName.parseFrom(byte[] data)
Get a ServerName from the passed in data bytes.
|
static ClusterId |
ClusterId.parseFrom(byte[] bytes) |
static SplitLogTask |
SplitLogTask.parseFrom(byte[] data) |
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 |
---|---|
private void |
ZKSplitLogManagerCoordination.getDataSetWatchSuccess(String path,
byte[] data,
int version) |
Modifier and Type | Method and Description |
---|---|
static MultipleColumnPrefixFilter |
MultipleColumnPrefixFilter.parseFrom(byte[] pbBytes) |
static TimestampsFilter |
TimestampsFilter.parseFrom(byte[] pbBytes) |
static ColumnPaginationFilter |
ColumnPaginationFilter.parseFrom(byte[] pbBytes) |
static SkipFilter |
SkipFilter.parseFrom(byte[] pbBytes) |
static PageFilter |
PageFilter.parseFrom(byte[] pbBytes) |
static SingleColumnValueFilter |
SingleColumnValueFilter.parseFrom(byte[] pbBytes) |
static QualifierFilter |
QualifierFilter.parseFrom(byte[] pbBytes) |
static FirstKeyOnlyFilter |
FirstKeyOnlyFilter.parseFrom(byte[] pbBytes) |
static FuzzyRowFilter |
FuzzyRowFilter.parseFrom(byte[] pbBytes) |
static ColumnCountGetFilter |
ColumnCountGetFilter.parseFrom(byte[] pbBytes) |
static ByteArrayComparable |
ByteArrayComparable.parseFrom(byte[] pbBytes) |
static RegexStringComparator |
RegexStringComparator.parseFrom(byte[] pbBytes) |
static KeyOnlyFilter |
KeyOnlyFilter.parseFrom(byte[] pbBytes) |
static FamilyFilter |
FamilyFilter.parseFrom(byte[] pbBytes) |
static FilterWrapper |
FilterWrapper.parseFrom(byte[] pbBytes) |
static RowFilter |
RowFilter.parseFrom(byte[] pbBytes) |
static BitComparator |
BitComparator.parseFrom(byte[] pbBytes) |
static InclusiveStopFilter |
InclusiveStopFilter.parseFrom(byte[] pbBytes) |
static LongComparator |
LongComparator.parseFrom(byte[] pbBytes) |
static PrefixFilter |
PrefixFilter.parseFrom(byte[] pbBytes) |
static NullComparator |
NullComparator.parseFrom(byte[] pbBytes) |
static BinaryComparator |
BinaryComparator.parseFrom(byte[] pbBytes) |
static FirstKeyValueMatchingQualifiersFilter |
FirstKeyValueMatchingQualifiersFilter.parseFrom(byte[] pbBytes) |
static ValueFilter |
ValueFilter.parseFrom(byte[] pbBytes) |
static WhileMatchFilter |
WhileMatchFilter.parseFrom(byte[] pbBytes) |
static SingleColumnValueExcludeFilter |
SingleColumnValueExcludeFilter.parseFrom(byte[] pbBytes) |
static ColumnPrefixFilter |
ColumnPrefixFilter.parseFrom(byte[] pbBytes) |
static FilterList |
FilterList.parseFrom(byte[] pbBytes) |
static BinaryPrefixComparator |
BinaryPrefixComparator.parseFrom(byte[] pbBytes) |
static MultiRowRangeFilter |
MultiRowRangeFilter.parseFrom(byte[] pbBytes) |
static RandomRowFilter |
RandomRowFilter.parseFrom(byte[] pbBytes) |
static Filter |
Filter.parseFrom(byte[] pbBytes)
Concrete implementers can signal a failure condition in their code by throwing an
IOException . |
static DependentColumnFilter |
DependentColumnFilter.parseFrom(byte[] pbBytes) |
static SubstringComparator |
SubstringComparator.parseFrom(byte[] pbBytes) |
static ColumnRangeFilter |
ColumnRangeFilter.parseFrom(byte[] pbBytes) |
Modifier and Type | Method and Description |
---|---|
private boolean |
AssignmentManager.isSplitOrSplittingOrMergedOrMerging(String path) |
Modifier and Type | Method and Description |
---|---|
void |
NamespaceUpgrade.upgradeTableDirs() |
Modifier and Type | Method and Description |
---|---|
static boolean |
ReplicationPeerZKImpl.isStateEnabled(byte[] bytes)
Parse the raw data from ZK to get a peer's state
|
private static ReplicationPeerConfig |
ReplicationPeersZKImpl.parsePeerFrom(byte[] bytes) |
private static org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationState.State |
ReplicationPeerZKImpl.parseStateFrom(byte[] bytes) |
private void |
ReplicationPeerZKImpl.readPeerStateZnode() |
Modifier and Type | Method and Description |
---|---|
static AccessControlFilter |
AccessControlFilter.parseFrom(byte[] pbBytes) |
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<org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel> |
VisibilityUtils.readLabelsFromZKData(byte[] data)
Reads back from the zookeeper.
|
static org.apache.hadoop.hbase.protobuf.generated.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
|
(package private) static String |
FSUtils.parseVersionFrom(byte[] bytes)
Parse the content of the ${HBASE_ROOTDIR}/hbase.version file.
|
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 org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.Master |
MasterAddressTracker.parse(byte[] data) |
private org.apache.hadoop.hbase.protobuf.generated.LoadBalancerProtos.LoadBalancerState |
LoadBalancerTracker.parseFrom(byte[] pbBytes) |
private org.apache.hadoop.hbase.protobuf.generated.RegionNormalizerProtos.RegionNormalizerState |
RegionNormalizerTracker.parseFrom(byte[] pbBytes) |
static org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds |
ZKUtil.parseRegionStoreSequenceIds(byte[] bytes) |
static long |
ZKUtil.parseWALPositionFrom(byte[] bytes) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.