Uses of Class
org.apache.hadoop.hbase.exceptions.DeserializationException
Packages that use 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
Methods in org.apache.hadoop.hbase that throw org.apache.hadoop.hbase.exceptions.DeserializationException in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.ClusterIdClusterId.parseFrom(byte[] bytes) Parse the serialized representation of theClusterIdstatic org.apache.hadoop.hbase.SplitLogTaskSplitLogTask.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 inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.security.visibility.AuthorizationsImmutableScan.getAuthorizations()org.apache.hadoop.hbase.security.visibility.AuthorizationsQuery.getAuthorizations()Returns The authorizations this Query is associated with.org.apache.hadoop.hbase.security.visibility.CellVisibilityMutation.getCellVisibility()Returns CellVisibility associated with cells in this Mutation.static org.apache.hadoop.hbase.client.ColumnFamilyDescriptorColumnFamilyDescriptorBuilder.parseFrom(byte[] pbBytes) static org.apache.hadoop.hbase.client.RegionInfoRegionInfo.parseFrom(byte[] bytes) Returns A deserializedRegionInfostatic org.apache.hadoop.hbase.client.RegionInfoRegionInfo.parseFrom(byte[] bytes, int offset, int len) Parse a serialized representation ofRegionInfostatic org.apache.hadoop.hbase.client.TableDescriptorTableDescriptorBuilder.parseFrom(byte[] pbBytes) The input should be created byTableDescriptorBuilder.toByteArray(org.apache.hadoop.hbase.client.TableDescriptor).static org.apache.hadoop.hbase.client.TableStateTableState.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 inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.replication.ReplicationPeerConfigReplicationPeerConfigUtil.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 inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.filter.BigDecimalComparatorBigDecimalComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofBigDecimalComparatorstatic org.apache.hadoop.hbase.filter.BinaryComparatorBinaryComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofBinaryComparatorstatic org.apache.hadoop.hbase.filter.BinaryComponentComparatorBinaryComponentComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofBinaryComponentComparatorstatic org.apache.hadoop.hbase.filter.BinaryPrefixComparatorBinaryPrefixComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofBinaryPrefixComparatorstatic org.apache.hadoop.hbase.filter.BitComparatorBitComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofBitComparatorstatic org.apache.hadoop.hbase.filter.ByteArrayComparableByteArrayComparable.parseFrom(byte[] pbBytes) Parse a serialized representation ofByteArrayComparablestatic org.apache.hadoop.hbase.filter.ColumnCountGetFilterColumnCountGetFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofColumnCountGetFilterstatic org.apache.hadoop.hbase.filter.ColumnPaginationFilterColumnPaginationFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofColumnPaginationFilterstatic org.apache.hadoop.hbase.filter.ColumnPrefixFilterColumnPrefixFilter.parseFrom(byte[] pbBytes) Parses a serialized representation of theColumnPrefixFilterstatic org.apache.hadoop.hbase.filter.ColumnRangeFilterColumnRangeFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofColumnRangeFilterstatic org.apache.hadoop.hbase.filter.ColumnValueFilterColumnValueFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofColumnValueFilterstatic org.apache.hadoop.hbase.filter.DependentColumnFilterDependentColumnFilter.parseFrom(byte[] pbBytes) Parse a seralized representation ofDependentColumnFilterstatic org.apache.hadoop.hbase.filter.FamilyFilterFamilyFilter.parseFrom(byte[] pbBytes) Parse the serialized representation ofFamilyFilterstatic org.apache.hadoop.hbase.filter.FilterFilter.parseFrom(byte[] pbBytes) Concrete implementers can signal a failure condition in their code by throwing anIOException.static org.apache.hadoop.hbase.filter.FilterAllFilterFilterAllFilter.parseFrom(byte[] pbBytes) static org.apache.hadoop.hbase.filter.FilterListFilterList.parseFrom(byte[] pbBytes) Parse a seralized representation ofFilterListstatic org.apache.hadoop.hbase.filter.FilterWrapperFilterWrapper.parseFrom(byte[] pbBytes) static org.apache.hadoop.hbase.filter.FirstKeyOnlyFilterFirstKeyOnlyFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofFirstKeyOnlyFilterstatic org.apache.hadoop.hbase.filter.FuzzyRowFilterFuzzyRowFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofFuzzyRowFilterstatic org.apache.hadoop.hbase.filter.InclusiveStopFilterInclusiveStopFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofInclusiveStopFilterstatic org.apache.hadoop.hbase.filter.KeyOnlyFilterKeyOnlyFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofKeyOnlyFilterstatic org.apache.hadoop.hbase.filter.LongComparatorLongComparator.parseFrom(byte[] pbBytes) Parses a serialized representation ofLongComparatorstatic org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilterMultipleColumnPrefixFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofMultipleColumnPrefixFilterstatic org.apache.hadoop.hbase.filter.MultiRowRangeFilterMultiRowRangeFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofMultiRowRangeFilterstatic org.apache.hadoop.hbase.filter.NullComparatorNullComparator.parseFrom(byte[] pbBytes) Parse the serialized representation ofNullComparatorstatic org.apache.hadoop.hbase.filter.PageFilterPageFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofPageFilterstatic org.apache.hadoop.hbase.filter.PrefixFilterPrefixFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofPrefixFilterstatic org.apache.hadoop.hbase.filter.QualifierFilterQualifierFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofQualifierFilterstatic org.apache.hadoop.hbase.filter.RandomRowFilterRandomRowFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofRandomRowFilterstatic org.apache.hadoop.hbase.filter.RegexStringComparatorRegexStringComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofRegexStringComparatorstatic org.apache.hadoop.hbase.filter.RowFilterRowFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofRowFilterstatic org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilterSingleColumnValueExcludeFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofSingleColumnValueExcludeFilterstatic org.apache.hadoop.hbase.filter.SingleColumnValueFilterSingleColumnValueFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofSingleColumnValueFilterstatic org.apache.hadoop.hbase.filter.SkipFilterSkipFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofSkipFilterstatic org.apache.hadoop.hbase.filter.SubstringComparatorSubstringComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofSubstringComparatorstatic org.apache.hadoop.hbase.filter.TimestampsFilterTimestampsFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofTimestampsFilterstatic org.apache.hadoop.hbase.filter.ValueFilterValueFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofValueFilterstatic org.apache.hadoop.hbase.filter.WhileMatchFilterWhileMatchFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofWhileMatchFilter -
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 inModifier and TypeMethodDescriptionprotected abstract booleanBooleanStateStore.parseFrom(byte[] bytes) Constructors in org.apache.hadoop.hbase.master that throw org.apache.hadoop.hbase.exceptions.DeserializationException in inModifierConstructorDescriptionprotectedBooleanStateStore(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 inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.MergeTableRegionsRequestRequestConverter.buildMergeTableRegionsRequest(byte[][] encodedNameOfdaughaterRegions, boolean forcible, long nonceGroup, long nonce) static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.SplitTableRegionRequestRequestConverter.buildSplitTableRegionRequest(org.apache.hadoop.hbase.client.RegionInfo regionInfo, byte[] splitRow, long nonceGroup, long nonce) static org.apache.hadoop.hbase.shaded.protobuf.generated.MasterProtos.TruncateRegionRequestRequestConverter.buildTruncateRegionRequest(org.apache.hadoop.hbase.client.RegionInfo regionInfo, long nonceGroup, long nonce) static voidProtobufUtil.expectPBMagicPrefix(byte[] bytes) Expect theProtobufMagic.PB_MAGICor throw an exception.static org.apache.hadoop.hbase.master.RegionStateProtobufUtil.parseMetaRegionStateFrom(byte[] data, int replicaId) Get the Meta region state from the passed data bytes.static org.apache.hadoop.hbase.ServerNameProtobufUtil.parseServerNameFrom(byte[] data) Get a ServerName from the passed in data bytes.static org.apache.hadoop.hbase.security.visibility.AuthorizationsProtobufUtil.toAuthorizations(byte[] protoBytes) Convert a protocol buffer Authorizations bytes to a client Authorizationsstatic org.apache.hadoop.hbase.security.visibility.CellVisibilityProtobufUtil.toCellVisibility(byte[] protoBytes) Convert a protocol buffer CellVisibility bytes to a client CellVisibilitystatic org.apache.hadoop.hbase.ServerNameProtobufUtil.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
Methods in org.apache.hadoop.hbase.util that throw org.apache.hadoop.hbase.exceptions.DeserializationException in inModifier and TypeMethodDescriptionstatic voidFSUtils.checkVersion(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootdir, boolean message) Verifies current version of file systemstatic voidFSUtils.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 StringFSUtils.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 inModifier and TypeMethodDescriptionstatic org.apache.zookeeper.KeeperExceptionZKUtil.convert(org.apache.hadoop.hbase.exceptions.DeserializationException e) Convert aDeserializationExceptionto a more palatableKeeperException.Methods in org.apache.hadoop.hbase.zookeeper that throw org.apache.hadoop.hbase.exceptions.DeserializationException in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ZooKeeperProtos.MasterMasterAddressTracker.parse(byte[] data) static longZKUtil.parseWALPositionFrom(byte[] bytes)