Uses of Class
org.apache.hadoop.hbase.exceptions.DeserializationException
Packages that use DeserializationException
Package
Description
Provides HBase Client
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next().The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
-
Uses of DeserializationException in org.apache.hadoop.hbase
Methods in org.apache.hadoop.hbase that throw DeserializationExceptionModifier and TypeMethodDescriptionstatic ClusterIdClusterId.parseFrom(byte[] bytes) Parse the serialized representation of theClusterIdstatic SplitLogTaskSplitLogTask.parseFrom(byte[] data) Deprecated. -
Uses of DeserializationException in org.apache.hadoop.hbase.client
Methods in org.apache.hadoop.hbase.client that throw DeserializationExceptionModifier and TypeMethodDescriptionImmutableScan.getAuthorizations()Query.getAuthorizations()Returns The authorizations this Query is associated with.Mutation.getCellVisibility()Returns CellVisibility associated with cells in this Mutation.private static StringZKConnectionRegistry.getClusterId(byte[] data) Deprecated.private static ColumnFamilyDescriptorColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptor.parseFrom(byte[] bytes) Parse the serialized representation of aColumnFamilyDescriptorBuilder.ModifyableColumnFamilyDescriptorstatic ColumnFamilyDescriptorColumnFamilyDescriptorBuilder.parseFrom(byte[] pbBytes) static RegionInfoRegionInfo.parseFrom(byte[] bytes) Returns A deserializedRegionInfostatic RegionInfoRegionInfo.parseFrom(byte[] bytes, int offset, int len) Parse a serialized representation ofRegionInfoprivate static TableDescriptorTableDescriptorBuilder.ModifyableTableDescriptor.parseFrom(byte[] bytes) static TableDescriptorTableDescriptorBuilder.parseFrom(byte[] pbBytes) The input should be created byTableDescriptorBuilder.toByteArray(org.apache.hadoop.hbase.client.TableDescriptor).static TableStateprivate static CellVisibilityMutation.toCellVisibility(byte[] protoBytes) Convert a protocol buffer CellVisibility bytes to a client CellVisibility -
Uses of DeserializationException in org.apache.hadoop.hbase.client.replication
Methods in org.apache.hadoop.hbase.client.replication that throw DeserializationExceptionModifier and TypeMethodDescriptionstatic ReplicationPeerConfigReplicationPeerConfigUtil.parsePeerFrom(byte[] bytes) Parse the serialized representation of a peer configuration. -
Uses of DeserializationException in org.apache.hadoop.hbase.coordination
Methods in org.apache.hadoop.hbase.coordination that throw DeserializationExceptionModifier and TypeMethodDescriptionprivate voidZKSplitLogManagerCoordination.getDataSetWatchSuccess(String path, byte[] data, int version) -
Uses of DeserializationException in org.apache.hadoop.hbase.filter
Methods in org.apache.hadoop.hbase.filter that throw DeserializationExceptionModifier and TypeMethodDescriptionstatic BigDecimalComparatorBigDecimalComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofBigDecimalComparatorstatic BinaryComparatorBinaryComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofBinaryComparatorstatic BinaryComponentComparatorBinaryComponentComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofBinaryComponentComparatorstatic BinaryPrefixComparatorBinaryPrefixComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofBinaryPrefixComparatorstatic BitComparatorBitComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofBitComparatorstatic ByteArrayComparableByteArrayComparable.parseFrom(byte[] pbBytes) Parse a serialized representation ofByteArrayComparablestatic ColumnCountGetFilterColumnCountGetFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofColumnCountGetFilterstatic ColumnPaginationFilterColumnPaginationFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofColumnPaginationFilterstatic ColumnPrefixFilterColumnPrefixFilter.parseFrom(byte[] pbBytes) Parses a serialized representation of theColumnPrefixFilterstatic ColumnRangeFilterColumnRangeFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofColumnRangeFilterstatic ColumnValueFilterColumnValueFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofColumnValueFilterstatic DependentColumnFilterDependentColumnFilter.parseFrom(byte[] pbBytes) Parse a seralized representation ofDependentColumnFilterstatic FamilyFilterFamilyFilter.parseFrom(byte[] pbBytes) Parse the serialized representation ofFamilyFilterstatic FilterFilter.parseFrom(byte[] pbBytes) Concrete implementers can signal a failure condition in their code by throwing anIOException.static FilterAllFilterFilterAllFilter.parseFrom(byte[] pbBytes) static FilterListFilterList.parseFrom(byte[] pbBytes) Parse a seralized representation ofFilterListstatic FilterWrapperFilterWrapper.parseFrom(byte[] pbBytes) static FirstKeyOnlyFilterFirstKeyOnlyFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofFirstKeyOnlyFilterstatic FuzzyRowFilterFuzzyRowFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofFuzzyRowFilterstatic InclusiveStopFilterInclusiveStopFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofInclusiveStopFilterstatic KeyOnlyFilterKeyOnlyFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofKeyOnlyFilterstatic LongComparatorLongComparator.parseFrom(byte[] pbBytes) Parses a serialized representation ofLongComparatorstatic MultipleColumnPrefixFilterMultipleColumnPrefixFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofMultipleColumnPrefixFilterstatic MultiRowRangeFilterMultiRowRangeFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofMultiRowRangeFilterstatic NullComparatorNullComparator.parseFrom(byte[] pbBytes) Parse the serialized representation ofNullComparatorstatic PageFilterPageFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofPageFilterstatic PrefixFilterPrefixFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofPrefixFilterstatic QualifierFilterQualifierFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofQualifierFilterstatic RandomRowFilterRandomRowFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofRandomRowFilterstatic RegexStringComparatorRegexStringComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofRegexStringComparatorstatic RowFilterRowFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofRowFilterSingleColumnValueExcludeFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofSingleColumnValueExcludeFilterstatic SingleColumnValueFilterSingleColumnValueFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofSingleColumnValueFilterstatic SkipFilterSkipFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofSkipFilterstatic SubstringComparatorSubstringComparator.parseFrom(byte[] pbBytes) Parse a serialized representation ofSubstringComparatorstatic TimestampsFilterTimestampsFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofTimestampsFilterstatic ValueFilterValueFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofValueFilterstatic WhileMatchFilterWhileMatchFilter.parseFrom(byte[] pbBytes) Parse a serialized representation ofWhileMatchFilter -
Uses of DeserializationException in org.apache.hadoop.hbase.master
Methods in org.apache.hadoop.hbase.master that throw DeserializationExceptionModifier and TypeMethodDescriptionprivate voidHMaster.finishActiveMasterInitialization()Finish initialization of HMaster after becoming the primary master.private voidHMaster.initializeZKBasedSystemTrackers()Initialize all ZK based system trackers.protected abstract booleanBooleanStateStore.parseFrom(byte[] bytes) protected booleanSplitOrMergeStateStore.SwitchStateStore.parseFrom(byte[] bytes) Constructors in org.apache.hadoop.hbase.master that throw DeserializationExceptionModifierConstructorDescriptionprotectedBooleanStateStore(MasterRegion masterRegion, String stateName, ZKWatcher watcher, String zkPath) SplitOrMergeStateStore(MasterRegion masterRegion, ZKWatcher watcher, org.apache.hadoop.conf.Configuration conf) SwitchStateStore(MasterRegion masterRegion, String stateName, ZKWatcher watcher, String zkPath) -
Uses of DeserializationException in org.apache.hadoop.hbase.master.balancer
Methods in org.apache.hadoop.hbase.master.balancer that throw DeserializationExceptionModifier and TypeMethodDescriptionprotected booleanLoadBalancerStateStore.parseFrom(byte[] pbBytes) Constructors in org.apache.hadoop.hbase.master.balancer that throw DeserializationExceptionModifierConstructorDescriptionLoadBalancerStateStore(MasterRegion masterRegion, ZKWatcher watcher) -
Uses of DeserializationException in org.apache.hadoop.hbase.master.normalizer
Methods in org.apache.hadoop.hbase.master.normalizer that throw DeserializationExceptionModifier and TypeMethodDescriptionstatic RegionNormalizerManagerRegionNormalizerFactory.createNormalizerManager(org.apache.hadoop.conf.Configuration conf, MasterRegion masterRegion, ZKWatcher zkWatcher, HMaster master) protected booleanRegionNormalizerStateStore.parseFrom(byte[] pbBytes) Constructors in org.apache.hadoop.hbase.master.normalizer that throw DeserializationExceptionModifierConstructorDescriptionRegionNormalizerStateStore(MasterRegion masterRegion, ZKWatcher watcher) -
Uses of DeserializationException in org.apache.hadoop.hbase.master.replication
Methods in org.apache.hadoop.hbase.master.replication that throw DeserializationExceptionModifier and TypeMethodDescriptionprotected booleanReplicationPeerModificationStateStore.parseFrom(byte[] bytes) Constructors in org.apache.hadoop.hbase.master.replication that throw DeserializationException -
Uses of DeserializationException in org.apache.hadoop.hbase.master.snapshot
Methods in org.apache.hadoop.hbase.master.snapshot that throw DeserializationExceptionModifier and TypeMethodDescriptionprotected booleanSnapshotCleanupStateStore.parseFrom(byte[] pbBytes) Constructors in org.apache.hadoop.hbase.master.snapshot that throw DeserializationExceptionModifierConstructorDescriptionSnapshotCleanupStateStore(MasterRegion masterRegion, ZKWatcher watcher) -
Uses of DeserializationException in org.apache.hadoop.hbase.security.access
Methods in org.apache.hadoop.hbase.security.access that throw DeserializationExceptionModifier and TypeMethodDescriptionstatic AccessControlFilterAccessControlFilter.parseFrom(byte[] pbBytes) static org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String,Permission> PermissionStorage.readPermissions(byte[] data, org.apache.hadoop.conf.Configuration conf) static org.apache.hbase.thirdparty.com.google.common.collect.ListMultimap<String,UserPermission> PermissionStorage.readUserPermission(byte[] data, org.apache.hadoop.conf.Configuration conf) -
Uses of DeserializationException in org.apache.hadoop.hbase.security.visibility
Methods in org.apache.hadoop.hbase.security.visibility that throw DeserializationExceptionModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.shaded.protobuf.generated.VisibilityLabelsProtos.VisibilityLabel>VisibilityUtils.readLabelsFromZKData(byte[] data) Reads back from the zookeeper.static org.apache.hadoop.hbase.shaded.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizationsVisibilityUtils.readUserAuthsFromZKData(byte[] data) Reads back User auth data written to zookeeper. -
Uses of DeserializationException in org.apache.hadoop.hbase.util
Methods in org.apache.hadoop.hbase.util that throw DeserializationExceptionModifier 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(package private) static StringFSUtils.parseVersionFrom(byte[] bytes) Parse the content of the ${HBASE_ROOTDIR}/hbase.version file. -
Uses of DeserializationException in org.apache.hadoop.hbase.zookeeper
Methods in org.apache.hadoop.hbase.zookeeper with parameters of type DeserializationExceptionModifier and TypeMethodDescriptionstatic org.apache.zookeeper.KeeperExceptionZKUtil.convert(DeserializationException e) Convert aDeserializationExceptionto a more palatableKeeperException.Methods in org.apache.hadoop.hbase.zookeeper that throw DeserializationExceptionModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ZooKeeperProtos.MasterMasterAddressTracker.parse(byte[] data) static longZKUtil.parseWALPositionFrom(byte[] bytes)