Uses of Class
org.apache.hadoop.hbase.exceptions.DeserializationException
Package
Description
Provides HBase Client
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next()
.-
Uses of org.apache.hadoop.hbase.exceptions.DeserializationException in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.ClusterId
ClusterId.parseFrom
(byte[] bytes) Parse the serialized representation of theClusterId
static org.apache.hadoop.hbase.SplitLogTask
SplitLogTask.parseFrom
(byte[] data) Deprecated. -
Uses of org.apache.hadoop.hbase.exceptions.DeserializationException in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.security.visibility.Authorizations
ImmutableScan.getAuthorizations()
org.apache.hadoop.hbase.security.visibility.Authorizations
Query.getAuthorizations()
Returns The authorizations this Query is associated with.org.apache.hadoop.hbase.security.visibility.CellVisibility
Mutation.getCellVisibility()
Returns CellVisibility associated with cells in this Mutation.static org.apache.hadoop.hbase.client.ColumnFamilyDescriptor
ColumnFamilyDescriptorBuilder.parseFrom
(byte[] pbBytes) static org.apache.hadoop.hbase.client.RegionInfo
RegionInfo.parseFrom
(byte[] bytes) Returns A deserializedRegionInfo
static org.apache.hadoop.hbase.client.RegionInfo
RegionInfo.parseFrom
(byte[] bytes, int offset, int len) Parse a serialized representation ofRegionInfo
static org.apache.hadoop.hbase.client.TableDescriptor
TableDescriptorBuilder.parseFrom
(byte[] pbBytes) The input should be created byTableDescriptorBuilder.toByteArray(org.apache.hadoop.hbase.client.TableDescriptor)
.static org.apache.hadoop.hbase.client.TableState
TableState.parseFrom
(org.apache.hadoop.hbase.TableName tableName, byte[] bytes) -
Uses of org.apache.hadoop.hbase.exceptions.DeserializationException in org.apache.hadoop.hbase.client.replication
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.replication.ReplicationPeerConfig
ReplicationPeerConfigUtil.parsePeerFrom
(byte[] bytes) Parse the serialized representation of a peer configuration. -
Uses of org.apache.hadoop.hbase.exceptions.DeserializationException in org.apache.hadoop.hbase.filter
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.filter.BigDecimalComparator
BigDecimalComparator.parseFrom
(byte[] pbBytes) Parse a serialized representation ofBigDecimalComparator
static org.apache.hadoop.hbase.filter.BinaryComparator
BinaryComparator.parseFrom
(byte[] pbBytes) Parse a serialized representation ofBinaryComparator
static org.apache.hadoop.hbase.filter.BinaryComponentComparator
BinaryComponentComparator.parseFrom
(byte[] pbBytes) Parse a serialized representation ofBinaryComponentComparator
static org.apache.hadoop.hbase.filter.BinaryPrefixComparator
BinaryPrefixComparator.parseFrom
(byte[] pbBytes) Parse a serialized representation ofBinaryPrefixComparator
static org.apache.hadoop.hbase.filter.BitComparator
BitComparator.parseFrom
(byte[] pbBytes) Parse a serialized representation ofBitComparator
static org.apache.hadoop.hbase.filter.ByteArrayComparable
ByteArrayComparable.parseFrom
(byte[] pbBytes) Parse a serialized representation ofByteArrayComparable
static org.apache.hadoop.hbase.filter.ColumnCountGetFilter
ColumnCountGetFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofColumnCountGetFilter
static org.apache.hadoop.hbase.filter.ColumnPaginationFilter
ColumnPaginationFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofColumnPaginationFilter
static org.apache.hadoop.hbase.filter.ColumnPrefixFilter
ColumnPrefixFilter.parseFrom
(byte[] pbBytes) Parses a serialized representation of theColumnPrefixFilter
static org.apache.hadoop.hbase.filter.ColumnRangeFilter
ColumnRangeFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofColumnRangeFilter
static org.apache.hadoop.hbase.filter.ColumnValueFilter
ColumnValueFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofColumnValueFilter
static org.apache.hadoop.hbase.filter.DependentColumnFilter
DependentColumnFilter.parseFrom
(byte[] pbBytes) Parse a seralized representation ofDependentColumnFilter
static org.apache.hadoop.hbase.filter.FamilyFilter
FamilyFilter.parseFrom
(byte[] pbBytes) Parse the serialized representation ofFamilyFilter
static org.apache.hadoop.hbase.filter.Filter
Filter.parseFrom
(byte[] pbBytes) Concrete implementers can signal a failure condition in their code by throwing anIOException
.static org.apache.hadoop.hbase.filter.FilterAllFilter
FilterAllFilter.parseFrom
(byte[] pbBytes) static org.apache.hadoop.hbase.filter.FilterList
FilterList.parseFrom
(byte[] pbBytes) Parse a seralized representation ofFilterList
static org.apache.hadoop.hbase.filter.FilterWrapper
FilterWrapper.parseFrom
(byte[] pbBytes) static org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
FirstKeyOnlyFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofFirstKeyOnlyFilter
static org.apache.hadoop.hbase.filter.FuzzyRowFilter
FuzzyRowFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofFuzzyRowFilter
static org.apache.hadoop.hbase.filter.InclusiveStopFilter
InclusiveStopFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofInclusiveStopFilter
static org.apache.hadoop.hbase.filter.KeyOnlyFilter
KeyOnlyFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofKeyOnlyFilter
static org.apache.hadoop.hbase.filter.LongComparator
LongComparator.parseFrom
(byte[] pbBytes) Parses a serialized representation ofLongComparator
static org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
MultipleColumnPrefixFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofMultipleColumnPrefixFilter
static org.apache.hadoop.hbase.filter.MultiRowRangeFilter
MultiRowRangeFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofMultiRowRangeFilter
static org.apache.hadoop.hbase.filter.NullComparator
NullComparator.parseFrom
(byte[] pbBytes) Parse the serialized representation ofNullComparator
static org.apache.hadoop.hbase.filter.PageFilter
PageFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofPageFilter
static org.apache.hadoop.hbase.filter.PrefixFilter
PrefixFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofPrefixFilter
static org.apache.hadoop.hbase.filter.QualifierFilter
QualifierFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofQualifierFilter
static org.apache.hadoop.hbase.filter.RandomRowFilter
RandomRowFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofRandomRowFilter
static org.apache.hadoop.hbase.filter.RegexStringComparator
RegexStringComparator.parseFrom
(byte[] pbBytes) Parse a serialized representation ofRegexStringComparator
static org.apache.hadoop.hbase.filter.RowFilter
RowFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofRowFilter
static org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
SingleColumnValueExcludeFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofSingleColumnValueExcludeFilter
static org.apache.hadoop.hbase.filter.SingleColumnValueFilter
SingleColumnValueFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofSingleColumnValueFilter
static org.apache.hadoop.hbase.filter.SkipFilter
SkipFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofSkipFilter
static org.apache.hadoop.hbase.filter.SubstringComparator
SubstringComparator.parseFrom
(byte[] pbBytes) Parse a serialized representation ofSubstringComparator
static org.apache.hadoop.hbase.filter.TimestampsFilter
TimestampsFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofTimestampsFilter
static org.apache.hadoop.hbase.filter.ValueFilter
ValueFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofValueFilter
static org.apache.hadoop.hbase.filter.WhileMatchFilter
WhileMatchFilter.parseFrom
(byte[] pbBytes) Parse a serialized representation ofWhileMatchFilter
-
Uses of org.apache.hadoop.hbase.exceptions.DeserializationException in org.apache.hadoop.hbase.master
Modifier and TypeMethodDescriptionprotected abstract boolean
BooleanStateStore.parseFrom
(byte[] bytes) ModifierConstructorDescriptionprotected
BooleanStateStore
(org.apache.hadoop.hbase.master.region.MasterRegion masterRegion, String stateName, org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, String zkPath) SplitOrMergeStateStore
(org.apache.hadoop.hbase.master.region.MasterRegion masterRegion, org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, org.apache.hadoop.conf.Configuration conf) -
Uses of org.apache.hadoop.hbase.exceptions.DeserializationException in org.apache.hadoop.hbase.shaded.protobuf
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsRequest
RequestConverter.buildMergeTableRegionsRequest
(byte[][] encodedNameOfdaughaterRegions, boolean forcible, long nonceGroup, long nonce) static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SplitTableRegionRequest
RequestConverter.buildSplitTableRegionRequest
(org.apache.hadoop.hbase.client.RegionInfo regionInfo, byte[] splitRow, long nonceGroup, long nonce) static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateRegionRequest
RequestConverter.buildTruncateRegionRequest
(org.apache.hadoop.hbase.client.RegionInfo regionInfo, long nonceGroup, long nonce) static void
ProtobufUtil.expectPBMagicPrefix
(byte[] bytes) Expect theProtobufMagic.PB_MAGIC
or throw an exception.static org.apache.hadoop.hbase.master.RegionState
ProtobufUtil.parseMetaRegionStateFrom
(byte[] data, int replicaId) Get the Meta region state from the passed data bytes.static org.apache.hadoop.hbase.ServerName
ProtobufUtil.parseServerNameFrom
(byte[] data) Get a ServerName from the passed in data bytes.static org.apache.hadoop.hbase.security.visibility.Authorizations
ProtobufUtil.toAuthorizations
(byte[] protoBytes) Convert a protocol buffer Authorizations bytes to a client Authorizationsstatic org.apache.hadoop.hbase.security.visibility.CellVisibility
ProtobufUtil.toCellVisibility
(byte[] protoBytes) Convert a protocol buffer CellVisibility bytes to a client CellVisibilitystatic org.apache.hadoop.hbase.ServerName
ProtobufUtil.toServerName
(byte[] data) Get a ServerName from the passed in data bytes. -
Uses of org.apache.hadoop.hbase.exceptions.DeserializationException in org.apache.hadoop.hbase.util
Modifier and TypeMethodDescriptionstatic void
FSUtils.checkVersion
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootdir, boolean message) Verifies current version of file systemstatic 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 systemstatic String
FSUtils.getVersion
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootdir) Verifies current version of file system -
Uses of org.apache.hadoop.hbase.exceptions.DeserializationException in org.apache.hadoop.hbase.zookeeper
Modifier and TypeMethodDescriptionstatic org.apache.zookeeper.KeeperException
ZKUtil.convert
(org.apache.hadoop.hbase.exceptions.DeserializationException e) Convert aDeserializationException
to a more palatableKeeperException
.Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ZooKeeperProtos.Master
MasterAddressTracker.parse
(byte[] data) static long
ZKUtil.parseWALPositionFrom
(byte[] bytes)