Uses of Class
org.apache.hadoop.hbase.exceptions.DeserializationException

Packages that use org.apache.hadoop.hbase.exceptions.DeserializationException
  • Uses of org.apache.hadoop.hbase.exceptions.DeserializationException in org.apache.hadoop.hbase

    Methods in org.apache.hadoop.hbase that throw org.apache.hadoop.hbase.exceptions.DeserializationException in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.ClusterId
    ClusterId.parseFrom(byte[] bytes)
    Parse the serialized representation of the ClusterId
    static org.apache.hadoop.hbase.HColumnDescriptor
    HColumnDescriptor.parseFrom(byte[] bytes)
    Deprecated.
    Parse a serialized representation of a HColumnDescriptor
    static org.apache.hadoop.hbase.HRegionInfo
    HRegionInfo.parseFrom(byte[] bytes)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseFrom(byte[]).
    static org.apache.hadoop.hbase.HRegionInfo
    HRegionInfo.parseFrom(byte[] bytes, int offset, int len)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.parseFrom(byte[], int, int).
    static org.apache.hadoop.hbase.HTableDescriptor
    HTableDescriptor.parseFrom(byte[] bytes)
    Deprecated.
    Parse the serialized representation of a HTableDescriptor
    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

    Methods in org.apache.hadoop.hbase.client that throw org.apache.hadoop.hbase.exceptions.DeserializationException in in
    Modifier and Type
    Method
    Description
    org.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 deserialized RegionInfo
    static org.apache.hadoop.hbase.client.RegionInfo
    RegionInfo.parseFrom(byte[] bytes, int offset, int len)
    Parse a serialized representation of RegionInfo
    static org.apache.hadoop.hbase.client.TableDescriptor
    TableDescriptorBuilder.parseFrom(byte[] pbBytes)
    The input should be created by TableDescriptorBuilder.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

    Methods in org.apache.hadoop.hbase.client.replication that throw org.apache.hadoop.hbase.exceptions.DeserializationException in in
    Modifier and Type
    Method
    Description
    static 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

    Methods in org.apache.hadoop.hbase.filter that throw org.apache.hadoop.hbase.exceptions.DeserializationException in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.filter.BigDecimalComparator
    BigDecimalComparator.parseFrom(byte[] pbBytes)
    Parse a serialized representation of BigDecimalComparator
    static org.apache.hadoop.hbase.filter.BinaryComparator
    BinaryComparator.parseFrom(byte[] pbBytes)
    Parse a serialized representation of BinaryComparator
    static org.apache.hadoop.hbase.filter.BinaryComponentComparator
    BinaryComponentComparator.parseFrom(byte[] pbBytes)
    Parse a serialized representation of BinaryComponentComparator
    static org.apache.hadoop.hbase.filter.BinaryPrefixComparator
    BinaryPrefixComparator.parseFrom(byte[] pbBytes)
    Parse a serialized representation of BinaryPrefixComparator
    static org.apache.hadoop.hbase.filter.BitComparator
    BitComparator.parseFrom(byte[] pbBytes)
    Parse a serialized representation of BitComparator
    static org.apache.hadoop.hbase.filter.ByteArrayComparable
    ByteArrayComparable.parseFrom(byte[] pbBytes)
    Parse a serialized representation of ByteArrayComparable
    static org.apache.hadoop.hbase.filter.ColumnCountGetFilter
    ColumnCountGetFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of ColumnCountGetFilter
    static org.apache.hadoop.hbase.filter.ColumnPaginationFilter
    ColumnPaginationFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of ColumnPaginationFilter
    static org.apache.hadoop.hbase.filter.ColumnPrefixFilter
    ColumnPrefixFilter.parseFrom(byte[] pbBytes)
    Parses a serialized representation of the ColumnPrefixFilter
    static org.apache.hadoop.hbase.filter.ColumnRangeFilter
    ColumnRangeFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of ColumnRangeFilter
    static org.apache.hadoop.hbase.filter.ColumnValueFilter
    ColumnValueFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of ColumnValueFilter
    static org.apache.hadoop.hbase.filter.DependentColumnFilter
    DependentColumnFilter.parseFrom(byte[] pbBytes)
    Parse a seralized representation of DependentColumnFilter
    static org.apache.hadoop.hbase.filter.FamilyFilter
    FamilyFilter.parseFrom(byte[] pbBytes)
    Parse the serialized representation of FamilyFilter
    static org.apache.hadoop.hbase.filter.Filter
    Filter.parseFrom(byte[] pbBytes)
    Concrete implementers can signal a failure condition in their code by throwing an IOException.
    static org.apache.hadoop.hbase.filter.FilterList
    FilterList.parseFrom(byte[] pbBytes)
    Parse a seralized representation of FilterList
    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 of FirstKeyOnlyFilter
    static org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
    FirstKeyValueMatchingQualifiersFilter.parseFrom(byte[] pbBytes)
    Deprecated.
    Parses a serialized representation of FirstKeyValueMatchingQualifiersFilter
    static org.apache.hadoop.hbase.filter.FuzzyRowFilter
    FuzzyRowFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of FuzzyRowFilter
    static org.apache.hadoop.hbase.filter.InclusiveStopFilter
    InclusiveStopFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of InclusiveStopFilter
    static org.apache.hadoop.hbase.filter.KeyOnlyFilter
    KeyOnlyFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of KeyOnlyFilter
    static org.apache.hadoop.hbase.filter.LongComparator
    LongComparator.parseFrom(byte[] pbBytes)
    Parses a serialized representation of LongComparator
    static org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
    MultipleColumnPrefixFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of MultipleColumnPrefixFilter
    static org.apache.hadoop.hbase.filter.MultiRowRangeFilter
    MultiRowRangeFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of MultiRowRangeFilter
    static org.apache.hadoop.hbase.filter.NullComparator
    NullComparator.parseFrom(byte[] pbBytes)
    Parse the serialized representation of NullComparator
    static org.apache.hadoop.hbase.filter.PageFilter
    PageFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of PageFilter
    static org.apache.hadoop.hbase.filter.PrefixFilter
    PrefixFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of PrefixFilter
    static org.apache.hadoop.hbase.filter.QualifierFilter
    QualifierFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of QualifierFilter
    static org.apache.hadoop.hbase.filter.RandomRowFilter
    RandomRowFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of RandomRowFilter
    static org.apache.hadoop.hbase.filter.RegexStringComparator
    RegexStringComparator.parseFrom(byte[] pbBytes)
    Parse a serialized representation of RegexStringComparator
    static org.apache.hadoop.hbase.filter.RowFilter
    RowFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of RowFilter
    static org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
    SingleColumnValueExcludeFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of SingleColumnValueExcludeFilter
    static org.apache.hadoop.hbase.filter.SingleColumnValueFilter
    SingleColumnValueFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of SingleColumnValueFilter
    static org.apache.hadoop.hbase.filter.SkipFilter
    SkipFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of SkipFilter
    static org.apache.hadoop.hbase.filter.SubstringComparator
    SubstringComparator.parseFrom(byte[] pbBytes)
    Parse a serialized representation of SubstringComparator
    static org.apache.hadoop.hbase.filter.TimestampsFilter
    TimestampsFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of TimestampsFilter
    static org.apache.hadoop.hbase.filter.ValueFilter
    ValueFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of ValueFilter
    static org.apache.hadoop.hbase.filter.WhileMatchFilter
    WhileMatchFilter.parseFrom(byte[] pbBytes)
    Parse a serialized representation of WhileMatchFilter
  • Uses of org.apache.hadoop.hbase.exceptions.DeserializationException in org.apache.hadoop.hbase.master

    Methods in org.apache.hadoop.hbase.master that throw org.apache.hadoop.hbase.exceptions.DeserializationException in in
    Modifier and Type
    Method
    Description
    protected abstract boolean
    BooleanStateStore.parseFrom(byte[] bytes)
     
    Constructors in org.apache.hadoop.hbase.master that throw org.apache.hadoop.hbase.exceptions.DeserializationException in in
    Modifier
    Constructor
    Description
    protected
    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

    Methods in org.apache.hadoop.hbase.shaded.protobuf that throw org.apache.hadoop.hbase.exceptions.DeserializationException in in
    Modifier and Type
    Method
    Description
    static 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 the ProtobufMagic.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 Authorizations
    static org.apache.hadoop.hbase.security.visibility.CellVisibility
    ProtobufUtil.toCellVisibility(byte[] protoBytes)
    Convert a protocol buffer CellVisibility bytes to a client CellVisibility
  • Uses of org.apache.hadoop.hbase.exceptions.DeserializationException in org.apache.hadoop.hbase.util

    Methods in org.apache.hadoop.hbase.util that throw org.apache.hadoop.hbase.exceptions.DeserializationException in in
    Modifier and Type
    Method
    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
  • Uses of org.apache.hadoop.hbase.exceptions.DeserializationException in org.apache.hadoop.hbase.zookeeper

    Methods in org.apache.hadoop.hbase.zookeeper with parameters of type org.apache.hadoop.hbase.exceptions.DeserializationException in in
    Modifier and Type
    Method
    Description
    static org.apache.zookeeper.KeeperException
    ZKUtil.convert(org.apache.hadoop.hbase.exceptions.DeserializationException e)
    Convert a DeserializationException to a more palatable KeeperException.
    Methods in org.apache.hadoop.hbase.zookeeper that throw org.apache.hadoop.hbase.exceptions.DeserializationException in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.shaded.protobuf.generated.ZooKeeperProtos.Master
    MasterAddressTracker.parse(byte[] data)
     
    static long
    ZKUtil.parseWALPositionFrom(byte[] bytes)