API compatibility report for the hbase library between rel/2.0.0 and 3.0.0-beta-1RC0 versions


Binary
Compatibility
Source
Compatibility

Test Info


Library Namehbase
Version #1rel/2.0.0
Version #23.0.0-beta-1RC0
SubjectBinary Compatibility

Test Results


Total Java Modules22
Total Methods / Classes7356 / 616
Compatibility 64%

Problem Summary


SeverityCount
Added Methods-2614
Removed MethodsHigh852
Problems with
Data Types
High127
Medium34
Low26
Problems with
Methods
High18
Medium0
Low8
Other Changes
in Data Types
-283
Other Changes
in Methods
-83

Added Methods  2614 


hbase-endpoint-3.0.0-beta-1.jar, AggregationClient.class
package org.apache.hadoop.hbase.client.coprocessor
AggregationClient.AggregationClient ( )
AggregationClient.AggregationClient ( Connection connection )

hbase-it-3.0.0-beta-1.jar, ChaosConstants.class
package org.apache.hadoop.hbase.chaos
ChaosConstants.ChaosConstants ( )

hbase-rest-3.0.0-beta-1.jar, Client.class
package org.apache.hadoop.hbase.rest.client
Client.Client ( Cluster cluster, Configuration conf, boolean sslEnabled )
Client.Client ( Cluster cluster, Configuration conf, String trustStorePath, Optional<String> trustStorePassword, Optional<String> trustStoreType )
Client.Client ( Cluster cluster, String trustStorePath, Optional<String> trustStorePassword, Optional<String> trustStoreType )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AccessControlClient.class
package org.apache.hadoop.hbase.security.access
AccessControlClient.getUserPermissions ( Connection connection, String tableRegex, byte[ ] columnFamily ) [static]  :  List<UserPermission>
AccessControlClient.getUserPermissions ( Connection connection, String tableRegex, byte[ ] columnFamily, byte[ ] columnQualifier ) [static]  :  List<UserPermission>
AccessControlClient.getUserPermissions ( Connection connection, String tableRegex, byte[ ] columnFamily, byte[ ] columnQualifier, String userName ) [static]  :  List<UserPermission>
AccessControlClient.getUserPermissions ( Connection connection, String tableRegex, byte[ ] columnFamily, String userName ) [static]  :  List<UserPermission>
AccessControlClient.getUserPermissions ( Connection connection, String tableRegex, String userName ) [static]  :  List<UserPermission>
AccessControlClient.hasPermission ( Connection connection, String tableName, byte[ ] columnFamily, byte[ ] columnQualifier, String userName, Permission.Action... actions ) [static]  :  boolean
AccessControlClient.hasPermission ( Connection connection, String tableName, String columnFamily, String columnQualifier, String userName, Permission.Action... actions ) [static]  :  boolean

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ACL.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.data
ACL.ACL ( )
ACL.ACL ( int perms, Id id )
ACL.compareTo ( Object peer_ )  :  int
ACL.deserialize ( InputArchive a_, String tag )  :  void
ACL.equals ( Object peer_ )  :  boolean
ACL.getId ( )  :  Id
ACL.getPerms ( )  :  int
ACL.hashCode ( )  :  int
ACL.readFields ( DataInput in )  :  void
ACL.serialize ( OutputArchive a_, String tag )  :  void
ACL.setId ( Id m_ )  :  void
ACL.setPerms ( int m_ )  :  void
ACL.signature ( ) [static]  :  String
ACL.toString ( )  :  String
ACL.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ACLCallback.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
AsyncCallback.ACLCallback.processResult ( int p1, String p2, Object p3, List<ACL> p4, Stat p5 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Address.class
package org.apache.hadoop.hbase.net
Address.fromSocketAddress ( InetSocketAddress addr ) [static]  :  Address
Address.getHostName ( )  :  String
Address.toSocketAddress ( Address addr ) [static]  :  InetSocketAddress
Address.toSocketAddress ( Address[ ] addrs ) [static]  :  InetSocketAddress[ ]

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AddWatchRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
AddWatchRequest.AddWatchRequest ( )
AddWatchRequest.AddWatchRequest ( String path, int mode )
AddWatchRequest.compareTo ( Object peer_ )  :  int
AddWatchRequest.deserialize ( InputArchive a_, String tag )  :  void
AddWatchRequest.equals ( Object peer_ )  :  boolean
AddWatchRequest.getMode ( )  :  int
AddWatchRequest.getPath ( )  :  String
AddWatchRequest.hashCode ( )  :  int
AddWatchRequest.readFields ( DataInput in )  :  void
AddWatchRequest.serialize ( OutputArchive a_, String tag )  :  void
AddWatchRequest.setMode ( int m_ )  :  void
AddWatchRequest.setPath ( String m_ )  :  void
AddWatchRequest.signature ( ) [static]  :  String
AddWatchRequest.toString ( )  :  String
AddWatchRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Admin.class
package org.apache.hadoop.hbase.client
Admin.addReplicationPeerAsync ( String p1, ReplicationPeerConfig p2, boolean p3 ) [abstract]  :  Future<Void>
Admin.addReplicationPeerAsync ( String peerId, ReplicationPeerConfig peerConfig )  :  Future<Void>
Admin.addRSGroup ( String p1 ) [abstract]  :  void
Admin.balance ( BalanceRequest p1 ) [abstract]  :  BalanceResponse
Admin.balanceRSGroup ( String groupName )  :  BalanceResponse
Admin.balanceRSGroup ( String p1, BalanceRequest p2 ) [abstract]  :  BalanceResponse
Admin.clearSlowLogResponses ( Set<ServerName> p1 ) [abstract]  :  List<Boolean>
Admin.cloneSnapshot ( String snapshotName, TableName tableName, boolean restoreAcl, String customSFT )  :  void
Admin.cloneSnapshotAsync ( String p1, TableName p2, boolean p3, String p4 ) [abstract]  :  Future<Void>
Admin.cloneSnapshotAsync ( String snapshotName, TableName tableName, boolean restoreAcl )  :  Future<Void>
Admin.cloneTableSchema ( TableName p1, TableName p2, boolean p3 ) [abstract]  :  void
Admin.compactionSwitch ( boolean p1, List<String> p2 ) [abstract]  :  Map<ServerName,Boolean>
Admin.createTableAsync ( TableDescriptor p1 ) [abstract]  :  Future<Void>
Admin.disableReplicationPeerAsync ( String p1 ) [abstract]  :  Future<Void>
Admin.enableReplicationPeerAsync ( String p1 ) [abstract]  :  Future<Void>
Admin.exceedThrottleQuotaSwitch ( boolean p1 ) [abstract]  :  boolean
Admin.flush ( TableName p1, byte[ ] p2 ) [abstract]  :  void
Admin.flush ( TableName p1, List<byte[ ]> p2 ) [abstract]  :  void
Admin.flushMasterStore ( ) [abstract]  :  void
Admin.flushRegion ( byte[ ] p1, byte[ ] p2 ) [abstract]  :  void
Admin.getCachedFilesList ( ServerName p1 ) [abstract]  :  List<String>
Admin.getConfiguredNamespacesAndTablesInRSGroup ( String p1 ) [abstract]  :  Pair<List<String>,List<TableName>>
Admin.getCurrentSpaceQuotaSnapshot ( String p1 ) [abstract]  :  SpaceQuotaSnapshotView
Admin.getCurrentSpaceQuotaSnapshot ( TableName p1 ) [abstract]  :  SpaceQuotaSnapshotView
Admin.getLogEntries ( Set<ServerName> p1, String p2, ServerType p3, int p4, Map<String,Object> p5 ) [abstract]  :  List<LogEntry>
Admin.getRegionServers ( boolean excludeDecommissionedRS )  :  Collection<ServerName>
Admin.getRegionServerSpaceQuotaSnapshots ( ServerName p1 ) [abstract]  :  SpaceQuotaSnapshotView>
Admin.getReplicationPeerSyncReplicationState ( String peerId )  :  SyncReplicationState
Admin.getRSGroup ( Address p1 ) [abstract]  :  RSGroupInfo
Admin.getRSGroup ( String p1 ) [abstract]  :  RSGroupInfo
Admin.getRSGroup ( TableName p1 ) [abstract]  :  RSGroupInfo
Admin.getSlowLogResponses ( Set<ServerName> serverNames, LogQueryFilter logQueryFilter )  :  List<OnlineLogRecord> *DEPRECATED*
Admin.getSpaceQuotaTableSizes ( ) [abstract]  :  Map<TableName,Long>
Admin.getSyncWaitTimeout ( ) [abstract]  :  int
Admin.getUserPermissions ( GetUserPermissionsRequest p1 ) [abstract]  :  List<UserPermission>
Admin.grant ( UserPermission p1, boolean p2 ) [abstract]  :  void
Admin.hasUserPermissions ( List<Permission> permissions )  :  List<Boolean>
Admin.hasUserPermissions ( String p1, List<Permission> p2 ) [abstract]  :  List<Boolean>
Admin.isReplicationPeerEnabled ( String p1 ) [abstract]  :  boolean
Admin.isReplicationPeerModificationEnabled ( ) [abstract]  :  boolean
Admin.isRpcThrottleEnabled ( ) [abstract]  :  boolean
Admin.isSnapshotCleanupEnabled ( ) [abstract]  :  boolean
Admin.listNamespaces ( ) [abstract]  :  String[ ]
Admin.listRSGroups ( ) [abstract]  :  List<RSGroupInfo>
Admin.listTableDescriptors ( boolean p1 ) [abstract]  :  List<TableDescriptor>
Admin.listTableDescriptorsByState ( boolean p1 ) [abstract]  :  List<TableDescriptor>
Admin.listTableNamesByState ( boolean p1 ) [abstract]  :  List<TableName>
Admin.listTablesInRSGroup ( String p1 ) [abstract]  :  List<TableName>
Admin.listUnknownServers ( )  :  List<ServerName>
Admin.modifyColumnFamilyStoreFileTracker ( TableName tableName, byte[ ] family, String dstSFT )  :  void
Admin.modifyColumnFamilyStoreFileTrackerAsync ( TableName p1, byte[ ] p2, String p3 ) [abstract]  :  Future<Void>
Admin.modifyTableAsync ( TableDescriptor p1, boolean p2 ) [abstract]  :  Future<Void>
Admin.modifyTableStoreFileTracker ( TableName tableName, String dstSFT )  :  void
Admin.modifyTableStoreFileTrackerAsync ( TableName p1, String p2 ) [abstract]  :  Future<Void>
Admin.move ( byte[ ] p1 ) [abstract]  :  void
Admin.move ( byte[ ] p1, ServerName p2 ) [abstract]  :  void
Admin.moveServersToRSGroup ( Set<Address> p1, String p2 ) [abstract]  :  void
Admin.normalize ( NormalizeTableFilterParams p1 ) [abstract]  :  boolean
Admin.removeReplicationPeerAsync ( String p1 ) [abstract]  :  Future<Void>
Admin.removeRSGroup ( String p1 ) [abstract]  :  void
Admin.removeServersFromRSGroup ( Set<Address> p1 ) [abstract]  :  void
Admin.renameRSGroup ( String p1, String p2 ) [abstract]  :  void
Admin.replicationPeerModificationSwitch ( boolean on )  :  boolean
Admin.replicationPeerModificationSwitch ( boolean p1, boolean p2 ) [abstract]  :  boolean
Admin.revoke ( UserPermission p1 ) [abstract]  :  void
Admin.setRSGroup ( Set<TableName> p1, String p2 ) [abstract]  :  void
Admin.snapshot ( String snapshotName, TableName tableName, Map<String,Object> snapshotProps )  :  void
Admin.snapshot ( String snapshotName, TableName tableName, SnapshotType type, Map<String,Object> snapshotProps )  :  void
Admin.snapshotAsync ( SnapshotDescription p1 ) [abstract]  :  Future<Void>
Admin.snapshotCleanupSwitch ( boolean p1, boolean p2 ) [abstract]  :  boolean
Admin.splitRegionAsync ( byte[ ] p1 ) [abstract]  :  Future<Void>
Admin.switchRpcThrottle ( boolean p1 ) [abstract]  :  boolean
Admin.transitReplicationPeerSyncReplicationState ( String peerId, SyncReplicationState state )  :  void
Admin.transitReplicationPeerSyncReplicationStateAsync ( String p1, SyncReplicationState p2 ) [abstract]  :  Future<Void>
Admin.truncateRegion ( byte[ ] p1 ) [abstract]  :  void
Admin.truncateRegionAsync ( byte[ ] p1 ) [abstract]  :  Future<Void>
Admin.unassign ( byte[ ] p1 ) [abstract]  :  void
Admin.updateConfiguration ( String p1 ) [abstract]  :  void
Admin.updateReplicationPeerConfigAsync ( String p1, ReplicationPeerConfig p2 ) [abstract]  :  Future<Void>
Admin.updateRSGroupConfig ( String p1, Map<String,String> p2 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AdminServer.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.server.admin
AdminServer.setZooKeeperServer ( ZooKeeperServer p1 ) [abstract]  :  void
AdminServer.shutdown ( ) [abstract]  :  void
AdminServer.start ( ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AdminServerException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.server.admin
AdminServer.AdminServerException.AdminServer.AdminServerException ( String message, Throwable cause )
AdminServer.AdminServerException.AdminServer.AdminServerException ( Throwable cause )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Algorithm.class
package org.apache.hadoop.hbase.io.compress
Compression.Algorithm.reload ( Configuration p1 ) [abstract]  :  CompressionCodec

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AllChildrenNumberCallback.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
AsyncCallback.AllChildrenNumberCallback.processResult ( int p1, String p2, Object p3, int p4 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, APIErrorException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.APIErrorException.KeeperException.APIErrorException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Append.class
package org.apache.hadoop.hbase.client
Append.getCellBuilder ( CellBuilderType type )  :  CellBuilder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AsyncAdmin.class
package org.apache.hadoop.hbase.client
AsyncAdmin.addRSGroup ( String p1 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.balance ( BalanceRequest p1 ) [abstract]  :  CompletableFuture<BalanceResponse>
AsyncAdmin.balanceRSGroup ( String groupName )  :  CompletableFuture<BalanceResponse>
AsyncAdmin.balanceRSGroup ( String p1, BalanceRequest p2 ) [abstract]  :  CompletableFuture<BalanceResponse>
AsyncAdmin.balancerSwitch ( boolean p1, boolean p2 ) [abstract]  :  CompletableFuture<Boolean>
AsyncAdmin.clearSlowLogResponses ( Set<ServerName> p1 ) [abstract]  :  CompletableFuture<List<Boolean>>
AsyncAdmin.cloneSnapshot ( String p1, TableName p2, boolean p3, String p4 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.cloneSnapshot ( String snapshotName, TableName tableName, boolean restoreAcl )  :  CompletableFuture<Void>
AsyncAdmin.cloneTableSchema ( TableName p1, TableName p2, boolean p3 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.compactionSwitch ( boolean p1, List<String> p2 ) [abstract]  :  CompletableFuture<Map<ServerName,Boolean>>
AsyncAdmin.exceedThrottleQuotaSwitch ( boolean p1 ) [abstract]  :  CompletableFuture<Boolean>
AsyncAdmin.flush ( TableName p1, byte[ ] p2 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.flush ( TableName p1, List<byte[ ]> p2 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.flushMasterStore ( ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.flushRegion ( byte[ ] p1, byte[ ] p2 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.getCachedFilesList ( ServerName p1 ) [abstract]  :  CompletableFuture<List<String>>
AsyncAdmin.getConfiguredNamespacesAndTablesInRSGroup ( String p1 ) [abstract]  :  CompletableFuture<Pair<List<String>,List<TableName>>>
AsyncAdmin.getCurrentSpaceQuotaSnapshot ( String p1 ) [abstract]  :  CompletableFuture<?>
AsyncAdmin.getCurrentSpaceQuotaSnapshot ( TableName p1 ) [abstract]  :  CompletableFuture<?>
AsyncAdmin.getLogEntries ( Set<ServerName> p1, String p2, ServerType p3, int p4, Map<String,Object> p5 ) [abstract]  :  CompletableFuture<List<LogEntry>>
AsyncAdmin.getRegionServers ( boolean excludeDecommissionedRS )  :  CompletableFuture<Collection<ServerName>>
AsyncAdmin.getRegionServerSpaceQuotaSnapshots ( ServerName p1 ) [abstract]  :  CompletableFuture<?>
AsyncAdmin.getReplicationPeerSyncReplicationState ( String peerId )  :  CompletableFuture<SyncReplicationState>
AsyncAdmin.getRSGroup ( Address p1 ) [abstract]  :  CompletableFuture<RSGroupInfo>
AsyncAdmin.getRSGroup ( String p1 ) [abstract]  :  CompletableFuture<RSGroupInfo>
AsyncAdmin.getRSGroup ( TableName p1 ) [abstract]  :  CompletableFuture<RSGroupInfo>
AsyncAdmin.getSlowLogResponses ( Set<ServerName> serverNames, LogQueryFilter logQueryFilter )  :  CompletableFuture<List<OnlineLogRecord>> *DEPRECATED*
AsyncAdmin.getSpaceQuotaTableSizes ( ) [abstract]  :  CompletableFuture<Map<TableName,Long>>
AsyncAdmin.getUserPermissions ( GetUserPermissionsRequest p1 ) [abstract]  :  CompletableFuture<List<UserPermission>>
AsyncAdmin.grant ( UserPermission p1, boolean p2 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.hasUserPermissions ( List<Permission> permissions )  :  CompletableFuture<List<Boolean>>
AsyncAdmin.hasUserPermissions ( String p1, List<Permission> p2 ) [abstract]  :  CompletableFuture<List<Boolean>>
AsyncAdmin.isReplicationPeerEnabled ( String p1 ) [abstract]  :  CompletableFuture<Boolean>
AsyncAdmin.isReplicationPeerModificationEnabled ( ) [abstract]  :  CompletableFuture<Boolean>
AsyncAdmin.isRpcThrottleEnabled ( ) [abstract]  :  CompletableFuture<Boolean>
AsyncAdmin.isSnapshotCleanupEnabled ( ) [abstract]  :  CompletableFuture<Boolean>
AsyncAdmin.listNamespaces ( ) [abstract]  :  CompletableFuture<List<String>>
AsyncAdmin.listRSGroups ( ) [abstract]  :  CompletableFuture<List<RSGroupInfo>>
AsyncAdmin.listTableDescriptors ( List<TableName> p1 ) [abstract]  :  CompletableFuture<List<TableDescriptor>>
AsyncAdmin.listTableDescriptorsByState ( boolean p1 ) [abstract]  :  CompletableFuture<List<TableDescriptor>>
AsyncAdmin.listTableNamesByState ( boolean p1 ) [abstract]  :  CompletableFuture<List<TableName>>
AsyncAdmin.listTablesInRSGroup ( String p1 ) [abstract]  :  CompletableFuture<List<TableName>>
AsyncAdmin.listUnknownServers ( )  :  CompletableFuture<List<ServerName>>
AsyncAdmin.mergeRegions ( List<byte[ ]> p1, boolean p2 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.mergeSwitch ( boolean p1, boolean p2 ) [abstract]  :  CompletableFuture<Boolean>
AsyncAdmin.modifyColumnFamilyStoreFileTracker ( TableName p1, byte[ ] p2, String p3 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.modifyTable ( TableDescriptor p1, boolean p2 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.modifyTableStoreFileTracker ( TableName p1, String p2 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.moveServersToRSGroup ( Set<Address> p1, String p2 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.normalize ( NormalizeTableFilterParams p1 ) [abstract]  :  CompletableFuture<Boolean>
AsyncAdmin.removeRSGroup ( String p1 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.removeServersFromRSGroup ( Set<Address> p1 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.renameRSGroup ( String p1, String p2 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.replicationPeerModificationSwitch ( boolean on )  :  CompletableFuture<Boolean>
AsyncAdmin.replicationPeerModificationSwitch ( boolean p1, boolean p2 ) [abstract]  :  CompletableFuture<Boolean>
AsyncAdmin.restoreSnapshot ( String p1, boolean p2, boolean p3 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.revoke ( UserPermission p1 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.setRSGroup ( Set<TableName> p1, String p2 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.snapshotCleanupSwitch ( boolean p1, boolean p2 ) [abstract]  :  CompletableFuture<Boolean>
AsyncAdmin.splitSwitch ( boolean p1, boolean p2 ) [abstract]  :  CompletableFuture<Boolean>
AsyncAdmin.switchRpcThrottle ( boolean p1 ) [abstract]  :  CompletableFuture<Boolean>
AsyncAdmin.transitReplicationPeerSyncReplicationState ( String p1, SyncReplicationState p2 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.truncateRegion ( byte[ ] p1 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.unassign ( byte[ ] p1 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.updateConfiguration ( String p1 ) [abstract]  :  CompletableFuture<Void>
AsyncAdmin.updateRSGroupConfig ( String p1, Map<String,String> p2 ) [abstract]  :  CompletableFuture<Void>

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AsyncAdminBuilder.class
package org.apache.hadoop.hbase.client
AsyncAdminBuilder.setRetryPauseForCQTBE ( long pause, TimeUnit unit )  :  AsyncAdminBuilder *DEPRECATED*
AsyncAdminBuilder.setRetryPauseForServerOverloaded ( long p1, TimeUnit p2 ) [abstract]  :  AsyncAdminBuilder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AsyncAdminClientUtils.class
package org.apache.hadoop.hbase.client
AsyncAdminClientUtils.coprocessorServiceOnAllRegionServers ( AsyncAdmin asyncAdmin, Function<RpcChannel,S> stubMaker, ServiceCaller<S,R> callable ) [static]  :  CompletableFuture<Map<ServerName,Object>>

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AsyncBufferedMutator.class
package org.apache.hadoop.hbase.client
AsyncBufferedMutator.getPeriodicalFlushTimeout ( TimeUnit unit )  :  long

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AsyncBufferedMutatorBuilder.class
package org.apache.hadoop.hbase.client
AsyncBufferedMutatorBuilder.disableWriteBufferPeriodicFlush ( )  :  AsyncBufferedMutatorBuilder
AsyncBufferedMutatorBuilder.setMaxKeyValueSize ( int p1 ) [abstract]  :  AsyncBufferedMutatorBuilder
AsyncBufferedMutatorBuilder.setWriteBufferPeriodicFlush ( long timeout, TimeUnit unit )  :  AsyncBufferedMutatorBuilder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AsyncConnection.class
package org.apache.hadoop.hbase.client
AsyncConnection.clearRegionLocationCache ( ) [abstract]  :  void
AsyncConnection.getHbck ( ) [abstract]  :  CompletableFuture<Hbck>
AsyncConnection.getHbck ( ServerName p1 ) [abstract]  :  Hbck
AsyncConnection.isClosed ( ) [abstract]  :  boolean
AsyncConnection.toConnection ( ) [abstract]  :  Connection

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AsyncTable.class
package org.apache.hadoop.hbase.client
AsyncTable<C>.checkAndMutate ( byte[ ] p1, Filter p2 ) [abstract]  :  AsyncTable.CheckAndMutateWithFilterBuilder *DEPRECATED*
AsyncTable<C>.checkAndMutate ( CheckAndMutate p1 ) [abstract]  :  CompletableFuture<CheckAndMutateResult>
AsyncTable<C>.checkAndMutate ( List<CheckAndMutate> p1 ) [abstract]  :  List<CompletableFuture<CheckAndMutateResult>>
AsyncTable<C>.checkAndMutateAll ( List<CheckAndMutate> checkAndMutates )  :  CompletableFuture<List<CheckAndMutateResult>>
AsyncTable<C>.getDescriptor ( ) [abstract]  :  CompletableFuture<TableDescriptor>
AsyncTable<C>.getRegionLocator ( ) [abstract]  :  AsyncTableRegionLocator
AsyncTable<C>.getRequestAttributes ( )  :  Map<String,byte[ ]>

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AsyncTableBuilder.class
package org.apache.hadoop.hbase.client
AsyncTableBuilder<C>.setRequestAttribute ( String p1, byte[ ] p2 ) [abstract]  :  AsyncTableBuilder<C>
AsyncTableBuilder<C>.setRetryPauseForCQTBE ( long pause, TimeUnit unit )  :  AsyncTableBuilder<C> *DEPRECATED*
AsyncTableBuilder<C>.setRetryPauseForServerOverloaded ( long p1, TimeUnit p2 ) [abstract]  :  AsyncTableBuilder<C>

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AsyncTableRegionLocator.class
package org.apache.hadoop.hbase.client
AsyncTableRegionLocator.clearRegionLocationCache ( ) [abstract]  :  void
AsyncTableRegionLocator.getAllRegionLocations ( ) [abstract]  :  CompletableFuture<List<HRegionLocation>>
AsyncTableRegionLocator.getEndKeys ( )  :  CompletableFuture<List<byte[ ]>>
AsyncTableRegionLocator.getRegionLocation ( byte[ ] p1, int p2, boolean p3 ) [abstract]  :  CompletableFuture<HRegionLocation>
AsyncTableRegionLocator.getRegionLocation ( byte[ ] row, int replicaId )  :  CompletableFuture<HRegionLocation>
AsyncTableRegionLocator.getRegionLocations ( byte[ ] p1, boolean p2 ) [abstract]  :  CompletableFuture<List<HRegionLocation>>
AsyncTableRegionLocator.getRegionLocations ( byte[ ] row )  :  CompletableFuture<List<HRegionLocation>>
AsyncTableRegionLocator.getStartEndKeys ( )  :  CompletableFuture<List<Pair<byte[ ],byte[ ]>>>
AsyncTableRegionLocator.getStartKeys ( )  :  CompletableFuture<List<byte[ ]>>

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AuthFailedException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.AuthFailedException.KeeperException.AuthFailedException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AuthPacket.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
AuthPacket.AuthPacket ( )
AuthPacket.AuthPacket ( int type, String scheme, byte[ ] auth )
AuthPacket.compareTo ( Object peer_ )  :  int
AuthPacket.deserialize ( InputArchive a_, String tag )  :  void
AuthPacket.equals ( Object peer_ )  :  boolean
AuthPacket.getAuth ( )  :  byte[ ]
AuthPacket.getScheme ( )  :  String
AuthPacket.getType ( )  :  int
AuthPacket.hashCode ( )  :  int
AuthPacket.readFields ( DataInput in )  :  void
AuthPacket.serialize ( OutputArchive a_, String tag )  :  void
AuthPacket.setAuth ( byte[ ] m_ )  :  void
AuthPacket.setScheme ( String m_ )  :  void
AuthPacket.setType ( int m_ )  :  void
AuthPacket.signature ( ) [static]  :  String
AuthPacket.toString ( )  :  String
AuthPacket.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, AuthUtil.class
package org.apache.hadoop.hbase
AuthUtil.getAuthRenewalChore ( UserGroupInformation user, Configuration conf ) [static]  :  ScheduledChore
AuthUtil.loginClient ( Configuration conf ) [static]  :  User

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, BadArgumentsException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.BadArgumentsException.KeeperException.BadArgumentsException ( )
KeeperException.BadArgumentsException.KeeperException.BadArgumentsException ( String path )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, BadVersionException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.BadVersionException.KeeperException.BadVersionException ( )
KeeperException.BadVersionException.KeeperException.BadVersionException ( String path )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, BalancerDecision.class
package org.apache.hadoop.hbase.client
BalancerDecision.getComputedSteps ( )  :  long
BalancerDecision.getComputedTotalCost ( )  :  double
BalancerDecision.getFinalFunctionCosts ( )  :  String
BalancerDecision.getInitialFunctionCosts ( )  :  String
BalancerDecision.getInitTotalCost ( )  :  double
BalancerDecision.getRegionPlans ( )  :  List<String>
BalancerDecision.toJsonPrettyPrint ( )  :  String
BalancerDecision.toString ( )  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, BalanceRequest.class
package org.apache.hadoop.hbase.client
BalanceRequest.defaultInstance ( ) [static]  :  BalanceRequest
BalanceRequest.isDryRun ( )  :  boolean
BalanceRequest.isIgnoreRegionsInTransition ( )  :  boolean
BalanceRequest.newBuilder ( ) [static]  :  BalanceRequest.Builder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, BalanceResponse.class
package org.apache.hadoop.hbase.client
BalanceResponse.getMovesCalculated ( )  :  int
BalanceResponse.getMovesExecuted ( )  :  int
BalanceResponse.isBalancerRan ( )  :  boolean
BalanceResponse.newBuilder ( ) [static]  :  BalanceResponse.Builder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, BalancerRejection.class
package org.apache.hadoop.hbase.client
BalancerRejection.getCostFuncInfoList ( )  :  List<String>
BalancerRejection.getReason ( )  :  String
BalancerRejection.toJsonPrettyPrint ( )  :  String
BalancerRejection.toString ( )  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, BinaryComponentComparator.class
package org.apache.hadoop.hbase.filter
BinaryComponentComparator.BinaryComponentComparator ( byte[ ] value, int offset )
BinaryComponentComparator.compareTo ( byte[ ] value )  :  int
BinaryComponentComparator.compareTo ( byte[ ] value, int offset, int length )  :  int
BinaryComponentComparator.compareTo ( Object p1 )  :  int
BinaryComponentComparator.equals ( Object other )  :  boolean
BinaryComponentComparator.hashCode ( )  :  int
BinaryComponentComparator.parseFrom ( byte[ ] pbBytes ) [static]  :  BinaryComponentComparator
BinaryComponentComparator.toByteArray ( )  :  byte[ ]

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, BufferedMutatorParams.class
package org.apache.hadoop.hbase.client
BufferedMutatorParams.operationTimeout ( int operationTimeout )  :  BufferedMutatorParams

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Builder.class
package org.apache.hadoop.hbase.client
BalanceRequest.Builder.build ( )  :  BalanceRequest
BalanceRequest.Builder.setDryRun ( boolean dryRun )  :  BalanceRequest.Builder
BalanceRequest.Builder.setIgnoreRegionsInTransition ( boolean ignoreRegionsInTransition )  :  BalanceRequest.Builder
CheckAndMutate.Builder.build ( Append append )  :  CheckAndMutate
CheckAndMutate.Builder.build ( Delete delete )  :  CheckAndMutate
CheckAndMutate.Builder.build ( Increment increment )  :  CheckAndMutate
CheckAndMutate.Builder.build ( Put put )  :  CheckAndMutate
CheckAndMutate.Builder.build ( RowMutations mutations )  :  CheckAndMutate
CheckAndMutate.Builder.ifEquals ( byte[ ] family, byte[ ] qualifier, byte[ ] value )  :  CheckAndMutate.Builder
CheckAndMutate.Builder.ifMatches ( byte[ ] family, byte[ ] qualifier, CompareOperator compareOp, byte[ ] value )  :  CheckAndMutate.Builder
CheckAndMutate.Builder.ifMatches ( Filter filter )  :  CheckAndMutate.Builder
CheckAndMutate.Builder.ifNotExists ( byte[ ] family, byte[ ] qualifier )  :  CheckAndMutate.Builder
CheckAndMutate.Builder.timeRange ( TimeRange timeRange )  :  CheckAndMutate.Builder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Bytes.class
package org.apache.hadoop.hbase.util
Bytes.secureRandom ( byte[ ] b ) [static]  :  void
Bytes.secureRandom ( byte[ ] b, int offset, int length ) [static]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CallTimeoutException.class
package org.apache.hadoop.hbase.ipc
CallTimeoutException.CallTimeoutException ( String message, Throwable cause )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Cell.class
package org.apache.hadoop.hbase
Cell.getSerializedSize ( ) [abstract]  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CellComparator.class
package org.apache.hadoop.hbase
CellComparator.compare ( Cell p1, Cell p2, boolean p3 ) [abstract]  :  int
CellComparator.compareRows ( byte[ ] leftRow, byte[ ] rightRow )  :  int
CellComparator.compareRows ( ByteBuffer row, Cell cell )  :  int
CellComparator.getSimpleComparator ( ) [abstract]  :  Comparator<Cell>

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CellUtil.class
package org.apache.hadoop.hbase
CellUtil.cloneIfNecessary ( ArrayList<Cell> cells ) [static]  :  void
CellUtil.cloneIfNecessary ( Cell cell ) [static]  :  Cell
CellUtil.getCellKeyAsString ( Cell cell, Function<Cell,String> rowConverter ) [static]  :  String
CellUtil.matchingColumnFamilyAndQualifierPrefix ( Cell left, byte[ ] fam, byte[ ] qual ) [static]  :  boolean
CellUtil.matchingFamily ( Cell left, byte lfamlength, Cell right, byte rfamlength ) [static]  :  boolean
CellUtil.matchingRows ( Cell left, short lrowlength, Cell right, short rrowlength ) [static]  :  boolean
CellUtil.matchingTags ( Cell left, Cell right ) [static]  :  boolean
CellUtil.matchingValue ( Cell left, Cell right, int lvlength, int rvlength ) [static]  :  boolean

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CheckAndMutate.class
package org.apache.hadoop.hbase.client
CheckAndMutate.getAction ( )  :  Row
CheckAndMutate.getCompareOp ( )  :  CompareOperator
CheckAndMutate.getFamily ( )  :  byte[ ]
CheckAndMutate.getFilter ( )  :  Filter
CheckAndMutate.getQualifier ( )  :  byte[ ]
CheckAndMutate.getRow ( )  :  byte[ ]
CheckAndMutate.getTimeRange ( )  :  TimeRange
CheckAndMutate.getValue ( )  :  byte[ ]
CheckAndMutate.hasFilter ( )  :  boolean
CheckAndMutate.newBuilder ( byte[ ] row ) [static]  :  CheckAndMutate.Builder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CheckAndMutateResult.class
package org.apache.hadoop.hbase.client
CheckAndMutateResult.CheckAndMutateResult ( boolean success, Result result )
CheckAndMutateResult.getResult ( )  :  Result
CheckAndMutateResult.isSuccess ( )  :  boolean

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CheckVersionRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
CheckVersionRequest.CheckVersionRequest ( )
CheckVersionRequest.CheckVersionRequest ( String path, int version )
CheckVersionRequest.compareTo ( Object peer_ )  :  int
CheckVersionRequest.deserialize ( InputArchive a_, String tag )  :  void
CheckVersionRequest.equals ( Object peer_ )  :  boolean
CheckVersionRequest.getPath ( )  :  String
CheckVersionRequest.getVersion ( )  :  int
CheckVersionRequest.hashCode ( )  :  int
CheckVersionRequest.readFields ( DataInput in )  :  void
CheckVersionRequest.serialize ( OutputArchive a_, String tag )  :  void
CheckVersionRequest.setPath ( String m_ )  :  void
CheckVersionRequest.setVersion ( int m_ )  :  void
CheckVersionRequest.signature ( ) [static]  :  String
CheckVersionRequest.toString ( )  :  String
CheckVersionRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CheckVersionTxn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
CheckVersionTxn.CheckVersionTxn ( )
CheckVersionTxn.CheckVersionTxn ( String path, int version )
CheckVersionTxn.compareTo ( Object peer_ )  :  int
CheckVersionTxn.deserialize ( InputArchive a_, String tag )  :  void
CheckVersionTxn.equals ( Object peer_ )  :  boolean
CheckVersionTxn.getPath ( )  :  String
CheckVersionTxn.getVersion ( )  :  int
CheckVersionTxn.hashCode ( )  :  int
CheckVersionTxn.readFields ( DataInput in )  :  void
CheckVersionTxn.serialize ( OutputArchive a_, String tag )  :  void
CheckVersionTxn.setPath ( String m_ )  :  void
CheckVersionTxn.setVersion ( int m_ )  :  void
CheckVersionTxn.signature ( ) [static]  :  String
CheckVersionTxn.toString ( )  :  String
CheckVersionTxn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CheckWatchesRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
CheckWatchesRequest.CheckWatchesRequest ( )
CheckWatchesRequest.CheckWatchesRequest ( String path, int type )
CheckWatchesRequest.compareTo ( Object peer_ )  :  int
CheckWatchesRequest.deserialize ( InputArchive a_, String tag )  :  void
CheckWatchesRequest.equals ( Object peer_ )  :  boolean
CheckWatchesRequest.getPath ( )  :  String
CheckWatchesRequest.getType ( )  :  int
CheckWatchesRequest.hashCode ( )  :  int
CheckWatchesRequest.readFields ( DataInput in )  :  void
CheckWatchesRequest.serialize ( OutputArchive a_, String tag )  :  void
CheckWatchesRequest.setPath ( String m_ )  :  void
CheckWatchesRequest.setType ( int m_ )  :  void
CheckWatchesRequest.signature ( ) [static]  :  String
CheckWatchesRequest.toString ( )  :  String
CheckWatchesRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Children2Callback.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
AsyncCallback.Children2Callback.processResult ( int p1, String p2, Object p3, List<String> p4, Stat p5 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ChildrenCallback.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
AsyncCallback.ChildrenCallback.processResult ( int p1, String p2, Object p3, List<String> p4 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ClientInfo.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.data
ClientInfo.ClientInfo ( )
ClientInfo.ClientInfo ( String authScheme, String user )
ClientInfo.compareTo ( Object peer_ )  :  int
ClientInfo.deserialize ( InputArchive a_, String tag )  :  void
ClientInfo.equals ( Object peer_ )  :  boolean
ClientInfo.getAuthScheme ( )  :  String
ClientInfo.getUser ( )  :  String
ClientInfo.hashCode ( )  :  int
ClientInfo.readFields ( DataInput in )  :  void
ClientInfo.serialize ( OutputArchive a_, String tag )  :  void
ClientInfo.setAuthScheme ( String m_ )  :  void
ClientInfo.setUser ( String m_ )  :  void
ClientInfo.signature ( ) [static]  :  String
ClientInfo.toString ( )  :  String
ClientInfo.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ClientTokenUtil.class
package org.apache.hadoop.hbase.security.token
ClientTokenUtil.obtainAndCacheToken ( Connection conn, User user ) [static]  :  void
ClientTokenUtil.obtainToken ( AsyncConnection conn ) [static]  :  CompletableFuture<Token<AuthenticationTokenIdentifier>>

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CloseSessionTxn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
CloseSessionTxn.CloseSessionTxn ( )
CloseSessionTxn.CloseSessionTxn ( List<String> paths2Delete )
CloseSessionTxn.compareTo ( Object peer_ )  :  int
CloseSessionTxn.deserialize ( InputArchive a_, String tag )  :  void
CloseSessionTxn.equals ( Object peer_ )  :  boolean
CloseSessionTxn.getPaths2Delete ( )  :  List<String>
CloseSessionTxn.hashCode ( )  :  int
CloseSessionTxn.readFields ( DataInput in )  :  void
CloseSessionTxn.serialize ( OutputArchive a_, String tag )  :  void
CloseSessionTxn.setPaths2Delete ( List<String> m_ )  :  void
CloseSessionTxn.signature ( ) [static]  :  String
CloseSessionTxn.toString ( )  :  String
CloseSessionTxn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ClusterMetrics.class
package org.apache.hadoop.hbase
ClusterMetrics.getDecommissionedServerNames ( ) [abstract]  :  List<ServerName>
ClusterMetrics.getMasterTasks ( ) [abstract]  :  List<ServerTask>
ClusterMetrics.getServersName ( ) [abstract]  :  List<ServerName>
ClusterMetrics.getTableRegionStatesCount ( ) [abstract]  :  Map<TableName,RegionStatesCount>
ClusterMetrics.getUnknownServerNames ( ) [abstract]  :  List<ServerName>

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Code.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.Code.get ( int code ) [static]  :  KeeperException.Code
KeeperException.Code.intValue ( )  :  int
KeeperException.Code.valueOf ( String name ) [static]  :  KeeperException.Code
KeeperException.Code.values ( ) [static]  :  KeeperException.Code[ ]

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ColumnCountGetFilter.class
package org.apache.hadoop.hbase.filter
ColumnCountGetFilter.equals ( Object obj )  :  boolean
ColumnCountGetFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ColumnFamilyDescriptor.class
package org.apache.hadoop.hbase.client
ColumnFamilyDescriptor.getIndexBlockEncoding ( ) [abstract]  :  IndexBlockEncoding
ColumnFamilyDescriptor.getMajorCompactionCompressionType ( ) [abstract]  :  Compression.Algorithm
ColumnFamilyDescriptor.getMinorCompactionCompressionType ( ) [abstract]  :  Compression.Algorithm
ColumnFamilyDescriptor.getValue ( String p1 ) [abstract]  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ColumnFamilyDescriptorBuilder.class
package org.apache.hadoop.hbase.client
ColumnFamilyDescriptorBuilder.setBlocksize ( String value )  :  ColumnFamilyDescriptorBuilder
ColumnFamilyDescriptorBuilder.setIndexBlockEncoding ( IndexBlockEncoding value )  :  ColumnFamilyDescriptorBuilder
ColumnFamilyDescriptorBuilder.setMajorCompactionCompressionType ( Compression.Algorithm value )  :  ColumnFamilyDescriptorBuilder
ColumnFamilyDescriptorBuilder.setMinorCompactionCompressionType ( Compression.Algorithm value )  :  ColumnFamilyDescriptorBuilder
ColumnFamilyDescriptorBuilder.setVersionsWithTimeToLive ( int retentionInterval, int versionAfterInterval )  :  ColumnFamilyDescriptorBuilder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ColumnPaginationFilter.class
package org.apache.hadoop.hbase.filter
ColumnPaginationFilter.equals ( Object obj )  :  boolean
ColumnPaginationFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ColumnPrefixFilter.class
package org.apache.hadoop.hbase.filter
ColumnPrefixFilter.equals ( Object obj )  :  boolean
ColumnPrefixFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ColumnRangeFilter.class
package org.apache.hadoop.hbase.filter
ColumnRangeFilter.equals ( Object obj )  :  boolean
ColumnRangeFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ColumnValueFilter.class
package org.apache.hadoop.hbase.filter
ColumnValueFilter.equals ( Object obj )  :  boolean
ColumnValueFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CompareFilter.class
package org.apache.hadoop.hbase.filter
CompareFilter.equals ( Object obj )  :  boolean
CompareFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ConcurrentTableModificationException.class
package org.apache.hadoop.hbase
ConcurrentTableModificationException.ConcurrentTableModificationException ( )
ConcurrentTableModificationException.ConcurrentTableModificationException ( byte[ ] tableName )
ConcurrentTableModificationException.ConcurrentTableModificationException ( String s )
ConcurrentTableModificationException.ConcurrentTableModificationException ( TableName tableName )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Connection.class
package org.apache.hadoop.hbase.client
Connection.clearRegionLocationCache ( ) [abstract]  :  void
Connection.getClusterId ( )  :  String
Connection.getHbck ( )  :  Hbck
Connection.getHbck ( ServerName masterServer )  :  Hbck
Connection.toAsyncConnection ( ) [abstract]  :  AsyncConnection

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ConnectionClosedException.class
package org.apache.hadoop.hbase.exceptions
ConnectionClosedException.ConnectionClosedException ( String message, Throwable cause )
ConnectionClosedException.ConnectionClosedException ( String string )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ConnectionClosingException.class
package org.apache.hadoop.hbase.exceptions
ConnectionClosingException.ConnectionClosingException ( String message, Throwable cause )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ConnectionFactory.class
package org.apache.hadoop.hbase.client
ConnectionFactory.createAsyncConnection ( Configuration conf, User user, Map<String,byte[ ]> connectionAttributes ) [static]  :  CompletableFuture<AsyncConnection>
ConnectionFactory.createConnection ( Configuration conf, ExecutorService pool, User user, Map<String,byte[ ]> connectionAttributes ) [static]  :  Connection

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ConnectionLossException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.ConnectionLossException.KeeperException.ConnectionLossException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ConnectRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
ConnectRequest.compareTo ( Object peer_ )  :  int
ConnectRequest.ConnectRequest ( )
ConnectRequest.ConnectRequest ( int protocolVersion, long lastZxidSeen, int timeOut, long sessionId, byte[ ] passwd )
ConnectRequest.deserialize ( InputArchive a_, String tag )  :  void
ConnectRequest.equals ( Object peer_ )  :  boolean
ConnectRequest.getLastZxidSeen ( )  :  long
ConnectRequest.getPasswd ( )  :  byte[ ]
ConnectRequest.getProtocolVersion ( )  :  int
ConnectRequest.getSessionId ( )  :  long
ConnectRequest.getTimeOut ( )  :  int
ConnectRequest.hashCode ( )  :  int
ConnectRequest.readFields ( DataInput in )  :  void
ConnectRequest.serialize ( OutputArchive a_, String tag )  :  void
ConnectRequest.setLastZxidSeen ( long m_ )  :  void
ConnectRequest.setPasswd ( byte[ ] m_ )  :  void
ConnectRequest.setProtocolVersion ( int m_ )  :  void
ConnectRequest.setSessionId ( long m_ )  :  void
ConnectRequest.setTimeOut ( int m_ )  :  void
ConnectRequest.signature ( ) [static]  :  String
ConnectRequest.toString ( )  :  String
ConnectRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ConnectResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
ConnectResponse.compareTo ( Object peer_ )  :  int
ConnectResponse.ConnectResponse ( )
ConnectResponse.ConnectResponse ( int protocolVersion, int timeOut, long sessionId, byte[ ] passwd )
ConnectResponse.deserialize ( InputArchive a_, String tag )  :  void
ConnectResponse.equals ( Object peer_ )  :  boolean
ConnectResponse.getPasswd ( )  :  byte[ ]
ConnectResponse.getProtocolVersion ( )  :  int
ConnectResponse.getSessionId ( )  :  long
ConnectResponse.getTimeOut ( )  :  int
ConnectResponse.hashCode ( )  :  int
ConnectResponse.readFields ( DataInput in )  :  void
ConnectResponse.serialize ( OutputArchive a_, String tag )  :  void
ConnectResponse.setPasswd ( byte[ ] m_ )  :  void
ConnectResponse.setProtocolVersion ( int m_ )  :  void
ConnectResponse.setSessionId ( long m_ )  :  void
ConnectResponse.setTimeOut ( int m_ )  :  void
ConnectResponse.signature ( ) [static]  :  String
ConnectResponse.toString ( )  :  String
ConnectResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Create2Callback.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
AsyncCallback.Create2Callback.processResult ( int p1, String p2, Object p3, String p4, Stat p5 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Create2Response.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
Create2Response.compareTo ( Object peer_ )  :  int
Create2Response.Create2Response ( )
Create2Response.Create2Response ( String path, Stat stat )
Create2Response.deserialize ( InputArchive a_, String tag )  :  void
Create2Response.equals ( Object peer_ )  :  boolean
Create2Response.getPath ( )  :  String
Create2Response.getStat ( )  :  Stat
Create2Response.hashCode ( )  :  int
Create2Response.readFields ( DataInput in )  :  void
Create2Response.serialize ( OutputArchive a_, String tag )  :  void
Create2Response.setPath ( String m_ )  :  void
Create2Response.setStat ( Stat m_ )  :  void
Create2Response.signature ( ) [static]  :  String
Create2Response.toString ( )  :  String
Create2Response.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CreateContainerTxn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
CreateContainerTxn.compareTo ( Object peer_ )  :  int
CreateContainerTxn.CreateContainerTxn ( )
CreateContainerTxn.CreateContainerTxn ( String path, byte[ ] data, List<ACL> acl, int parentCVersion )
CreateContainerTxn.deserialize ( InputArchive a_, String tag )  :  void
CreateContainerTxn.equals ( Object peer_ )  :  boolean
CreateContainerTxn.getAcl ( )  :  List<ACL>
CreateContainerTxn.getData ( )  :  byte[ ]
CreateContainerTxn.getParentCVersion ( )  :  int
CreateContainerTxn.getPath ( )  :  String
CreateContainerTxn.hashCode ( )  :  int
CreateContainerTxn.readFields ( DataInput in )  :  void
CreateContainerTxn.serialize ( OutputArchive a_, String tag )  :  void
CreateContainerTxn.setAcl ( List<ACL> m_ )  :  void
CreateContainerTxn.setData ( byte[ ] m_ )  :  void
CreateContainerTxn.setParentCVersion ( int m_ )  :  void
CreateContainerTxn.setPath ( String m_ )  :  void
CreateContainerTxn.signature ( ) [static]  :  String
CreateContainerTxn.toString ( )  :  String
CreateContainerTxn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CreateMode.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
CreateMode.fromFlag ( int flag ) [static]  :  CreateMode
CreateMode.fromFlag ( int flag, CreateMode defaultMode ) [static]  :  CreateMode
CreateMode.isContainer ( )  :  boolean
CreateMode.isEphemeral ( )  :  boolean
CreateMode.isSequential ( )  :  boolean
CreateMode.isTTL ( )  :  boolean
CreateMode.toFlag ( )  :  int
CreateMode.valueOf ( String name ) [static]  :  CreateMode
CreateMode.values ( ) [static]  :  CreateMode[ ]

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CreateRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
CreateRequest.compareTo ( Object peer_ )  :  int
CreateRequest.CreateRequest ( )
CreateRequest.CreateRequest ( String path, byte[ ] data, List<ACL> acl, int flags )
CreateRequest.deserialize ( InputArchive a_, String tag )  :  void
CreateRequest.equals ( Object peer_ )  :  boolean
CreateRequest.getAcl ( )  :  List<ACL>
CreateRequest.getData ( )  :  byte[ ]
CreateRequest.getFlags ( )  :  int
CreateRequest.getPath ( )  :  String
CreateRequest.hashCode ( )  :  int
CreateRequest.readFields ( DataInput in )  :  void
CreateRequest.serialize ( OutputArchive a_, String tag )  :  void
CreateRequest.setAcl ( List<ACL> m_ )  :  void
CreateRequest.setData ( byte[ ] m_ )  :  void
CreateRequest.setFlags ( int m_ )  :  void
CreateRequest.setPath ( String m_ )  :  void
CreateRequest.signature ( ) [static]  :  String
CreateRequest.toString ( )  :  String
CreateRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CreateResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
CreateResponse.compareTo ( Object peer_ )  :  int
CreateResponse.CreateResponse ( )
CreateResponse.CreateResponse ( String path )
CreateResponse.deserialize ( InputArchive a_, String tag )  :  void
CreateResponse.equals ( Object peer_ )  :  boolean
CreateResponse.getPath ( )  :  String
CreateResponse.hashCode ( )  :  int
CreateResponse.readFields ( DataInput in )  :  void
CreateResponse.serialize ( OutputArchive a_, String tag )  :  void
CreateResponse.setPath ( String m_ )  :  void
CreateResponse.signature ( ) [static]  :  String
CreateResponse.toString ( )  :  String
CreateResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CreateSessionTxn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
CreateSessionTxn.compareTo ( Object peer_ )  :  int
CreateSessionTxn.CreateSessionTxn ( )
CreateSessionTxn.CreateSessionTxn ( int timeOut )
CreateSessionTxn.deserialize ( InputArchive a_, String tag )  :  void
CreateSessionTxn.equals ( Object peer_ )  :  boolean
CreateSessionTxn.getTimeOut ( )  :  int
CreateSessionTxn.hashCode ( )  :  int
CreateSessionTxn.readFields ( DataInput in )  :  void
CreateSessionTxn.serialize ( OutputArchive a_, String tag )  :  void
CreateSessionTxn.setTimeOut ( int m_ )  :  void
CreateSessionTxn.signature ( ) [static]  :  String
CreateSessionTxn.toString ( )  :  String
CreateSessionTxn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CreateTTLRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
CreateTTLRequest.compareTo ( Object peer_ )  :  int
CreateTTLRequest.CreateTTLRequest ( )
CreateTTLRequest.CreateTTLRequest ( String path, byte[ ] data, List<ACL> acl, int flags, long ttl )
CreateTTLRequest.deserialize ( InputArchive a_, String tag )  :  void
CreateTTLRequest.equals ( Object peer_ )  :  boolean
CreateTTLRequest.getAcl ( )  :  List<ACL>
CreateTTLRequest.getData ( )  :  byte[ ]
CreateTTLRequest.getFlags ( )  :  int
CreateTTLRequest.getPath ( )  :  String
CreateTTLRequest.getTtl ( )  :  long
CreateTTLRequest.hashCode ( )  :  int
CreateTTLRequest.readFields ( DataInput in )  :  void
CreateTTLRequest.serialize ( OutputArchive a_, String tag )  :  void
CreateTTLRequest.setAcl ( List<ACL> m_ )  :  void
CreateTTLRequest.setData ( byte[ ] m_ )  :  void
CreateTTLRequest.setFlags ( int m_ )  :  void
CreateTTLRequest.setPath ( String m_ )  :  void
CreateTTLRequest.setTtl ( long m_ )  :  void
CreateTTLRequest.signature ( ) [static]  :  String
CreateTTLRequest.toString ( )  :  String
CreateTTLRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CreateTTLTxn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
CreateTTLTxn.compareTo ( Object peer_ )  :  int
CreateTTLTxn.CreateTTLTxn ( )
CreateTTLTxn.CreateTTLTxn ( String path, byte[ ] data, List<ACL> acl, int parentCVersion, long ttl )
CreateTTLTxn.deserialize ( InputArchive a_, String tag )  :  void
CreateTTLTxn.equals ( Object peer_ )  :  boolean
CreateTTLTxn.getAcl ( )  :  List<ACL>
CreateTTLTxn.getData ( )  :  byte[ ]
CreateTTLTxn.getParentCVersion ( )  :  int
CreateTTLTxn.getPath ( )  :  String
CreateTTLTxn.getTtl ( )  :  long
CreateTTLTxn.hashCode ( )  :  int
CreateTTLTxn.readFields ( DataInput in )  :  void
CreateTTLTxn.serialize ( OutputArchive a_, String tag )  :  void
CreateTTLTxn.setAcl ( List<ACL> m_ )  :  void
CreateTTLTxn.setData ( byte[ ] m_ )  :  void
CreateTTLTxn.setParentCVersion ( int m_ )  :  void
CreateTTLTxn.setPath ( String m_ )  :  void
CreateTTLTxn.setTtl ( long m_ )  :  void
CreateTTLTxn.signature ( ) [static]  :  String
CreateTTLTxn.toString ( )  :  String
CreateTTLTxn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CreateTxn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
CreateTxn.compareTo ( Object peer_ )  :  int
CreateTxn.CreateTxn ( )
CreateTxn.CreateTxn ( String path, byte[ ] data, List<ACL> acl, boolean ephemeral, int parentCVersion )
CreateTxn.deserialize ( InputArchive a_, String tag )  :  void
CreateTxn.equals ( Object peer_ )  :  boolean
CreateTxn.getAcl ( )  :  List<ACL>
CreateTxn.getData ( )  :  byte[ ]
CreateTxn.getEphemeral ( )  :  boolean
CreateTxn.getParentCVersion ( )  :  int
CreateTxn.getPath ( )  :  String
CreateTxn.hashCode ( )  :  int
CreateTxn.readFields ( DataInput in )  :  void
CreateTxn.serialize ( OutputArchive a_, String tag )  :  void
CreateTxn.setAcl ( List<ACL> m_ )  :  void
CreateTxn.setData ( byte[ ] m_ )  :  void
CreateTxn.setEphemeral ( boolean m_ )  :  void
CreateTxn.setParentCVersion ( int m_ )  :  void
CreateTxn.setPath ( String m_ )  :  void
CreateTxn.signature ( ) [static]  :  String
CreateTxn.toString ( )  :  String
CreateTxn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, CreateTxnV0.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
CreateTxnV0.compareTo ( Object peer_ )  :  int
CreateTxnV0.CreateTxnV0 ( )
CreateTxnV0.CreateTxnV0 ( String path, byte[ ] data, List<ACL> acl, boolean ephemeral )
CreateTxnV0.deserialize ( InputArchive a_, String tag )  :  void
CreateTxnV0.equals ( Object peer_ )  :  boolean
CreateTxnV0.getAcl ( )  :  List<ACL>
CreateTxnV0.getData ( )  :  byte[ ]
CreateTxnV0.getEphemeral ( )  :  boolean
CreateTxnV0.getPath ( )  :  String
CreateTxnV0.hashCode ( )  :  int
CreateTxnV0.readFields ( DataInput in )  :  void
CreateTxnV0.serialize ( OutputArchive a_, String tag )  :  void
CreateTxnV0.setAcl ( List<ACL> m_ )  :  void
CreateTxnV0.setData ( byte[ ] m_ )  :  void
CreateTxnV0.setEphemeral ( boolean m_ )  :  void
CreateTxnV0.setPath ( String m_ )  :  void
CreateTxnV0.signature ( ) [static]  :  String
CreateTxnV0.toString ( )  :  String
CreateTxnV0.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, DataCallback.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
AsyncCallback.DataCallback.processResult ( int p1, String p2, Object p3, byte[ ] p4, Stat p5 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, DataInconsistencyException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.DataInconsistencyException.KeeperException.DataInconsistencyException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Delete.class
package org.apache.hadoop.hbase.client
Delete.getCellBuilder ( CellBuilderType type )  :  CellBuilder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, DeleteRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
DeleteRequest.compareTo ( Object peer_ )  :  int
DeleteRequest.DeleteRequest ( )
DeleteRequest.DeleteRequest ( String path, int version )
DeleteRequest.deserialize ( InputArchive a_, String tag )  :  void
DeleteRequest.equals ( Object peer_ )  :  boolean
DeleteRequest.getPath ( )  :  String
DeleteRequest.getVersion ( )  :  int
DeleteRequest.hashCode ( )  :  int
DeleteRequest.readFields ( DataInput in )  :  void
DeleteRequest.serialize ( OutputArchive a_, String tag )  :  void
DeleteRequest.setPath ( String m_ )  :  void
DeleteRequest.setVersion ( int m_ )  :  void
DeleteRequest.signature ( ) [static]  :  String
DeleteRequest.toString ( )  :  String
DeleteRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, DeleteTxn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
DeleteTxn.compareTo ( Object peer_ )  :  int
DeleteTxn.DeleteTxn ( )
DeleteTxn.DeleteTxn ( String path )
DeleteTxn.deserialize ( InputArchive a_, String tag )  :  void
DeleteTxn.equals ( Object peer_ )  :  boolean
DeleteTxn.getPath ( )  :  String
DeleteTxn.hashCode ( )  :  int
DeleteTxn.readFields ( DataInput in )  :  void
DeleteTxn.serialize ( OutputArchive a_, String tag )  :  void
DeleteTxn.setPath ( String m_ )  :  void
DeleteTxn.signature ( ) [static]  :  String
DeleteTxn.toString ( )  :  String
DeleteTxn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, DependentColumnFilter.class
package org.apache.hadoop.hbase.filter
DependentColumnFilter.equals ( Object obj )  :  boolean
DependentColumnFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, DoNotRetryRegionException.class
package org.apache.hadoop.hbase.client
DoNotRetryRegionException.DoNotRetryRegionException ( String s, Throwable cause )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, DroppedSnapshotException.class
package org.apache.hadoop.hbase
DroppedSnapshotException.DroppedSnapshotException ( String message, Throwable cause )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Encryption.class
package org.apache.hadoop.hbase.io.crypto
Encryption.computeCryptoKeyHash ( Configuration conf, byte[ ] arg ) [static]  :  byte[ ]
Encryption.failOnHashAlgorithmMismatch ( Configuration conf ) [static]  :  boolean
Encryption.generateSecretKey ( Configuration conf, String cypherAlg, byte[ ]... args ) [static]  :  byte[ ]
Encryption.generateSecretKey ( Configuration conf, String cypherAlg, String... args ) [static]  :  byte[ ]
Encryption.getConfiguredHashAlgorithm ( Configuration conf ) [static]  :  String
Encryption.hashWithAlg ( String algorithm, byte[ ]... args ) [static]  :  byte[ ]
Encryption.isEncryptionEnabled ( Configuration conf ) [static]  :  boolean

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, EphemeralOnLocalSessionException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.EphemeralOnLocalSessionException.KeeperException.EphemeralOnLocalSessionException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ErrorResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
ErrorResponse.compareTo ( Object peer_ )  :  int
ErrorResponse.deserialize ( InputArchive a_, String tag )  :  void
ErrorResponse.equals ( Object peer_ )  :  boolean
ErrorResponse.ErrorResponse ( )
ErrorResponse.ErrorResponse ( int err )
ErrorResponse.getErr ( )  :  int
ErrorResponse.hashCode ( )  :  int
ErrorResponse.readFields ( DataInput in )  :  void
ErrorResponse.serialize ( OutputArchive a_, String tag )  :  void
ErrorResponse.setErr ( int m_ )  :  void
ErrorResponse.signature ( ) [static]  :  String
ErrorResponse.toString ( )  :  String
ErrorResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ErrorTxn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
ErrorTxn.compareTo ( Object peer_ )  :  int
ErrorTxn.deserialize ( InputArchive a_, String tag )  :  void
ErrorTxn.equals ( Object peer_ )  :  boolean
ErrorTxn.ErrorTxn ( )
ErrorTxn.ErrorTxn ( int err )
ErrorTxn.getErr ( )  :  int
ErrorTxn.hashCode ( )  :  int
ErrorTxn.readFields ( DataInput in )  :  void
ErrorTxn.serialize ( OutputArchive a_, String tag )  :  void
ErrorTxn.setErr ( int m_ )  :  void
ErrorTxn.signature ( ) [static]  :  String
ErrorTxn.toString ( )  :  String
ErrorTxn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, EventType.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
Watcher.Event.EventType.fromInt ( int intValue ) [static]  :  Watcher.Event.EventType
Watcher.Event.EventType.getIntValue ( )  :  int
Watcher.Event.EventType.valueOf ( String name ) [static]  :  Watcher.Event.EventType
Watcher.Event.EventType.values ( ) [static]  :  Watcher.Event.EventType[ ]

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ExistsRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
ExistsRequest.compareTo ( Object peer_ )  :  int
ExistsRequest.deserialize ( InputArchive a_, String tag )  :  void
ExistsRequest.equals ( Object peer_ )  :  boolean
ExistsRequest.ExistsRequest ( )
ExistsRequest.ExistsRequest ( String path, boolean watch )
ExistsRequest.getPath ( )  :  String
ExistsRequest.getWatch ( )  :  boolean
ExistsRequest.hashCode ( )  :  int
ExistsRequest.readFields ( DataInput in )  :  void
ExistsRequest.serialize ( OutputArchive a_, String tag )  :  void
ExistsRequest.setPath ( String m_ )  :  void
ExistsRequest.setWatch ( boolean m_ )  :  void
ExistsRequest.signature ( ) [static]  :  String
ExistsRequest.toString ( )  :  String
ExistsRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ExistsResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
ExistsResponse.compareTo ( Object peer_ )  :  int
ExistsResponse.deserialize ( InputArchive a_, String tag )  :  void
ExistsResponse.equals ( Object peer_ )  :  boolean
ExistsResponse.ExistsResponse ( )
ExistsResponse.ExistsResponse ( Stat stat )
ExistsResponse.getStat ( )  :  Stat
ExistsResponse.hashCode ( )  :  int
ExistsResponse.readFields ( DataInput in )  :  void
ExistsResponse.serialize ( OutputArchive a_, String tag )  :  void
ExistsResponse.setStat ( Stat m_ )  :  void
ExistsResponse.signature ( ) [static]  :  String
ExistsResponse.toString ( )  :  String
ExistsResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, FamilyFilter.class
package org.apache.hadoop.hbase.filter
FamilyFilter.equals ( Object obj )  :  boolean
FamilyFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, FileHeader.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.server.persistence
FileHeader.compareTo ( Object peer_ )  :  int
FileHeader.deserialize ( InputArchive a_, String tag )  :  void
FileHeader.equals ( Object peer_ )  :  boolean
FileHeader.FileHeader ( )
FileHeader.FileHeader ( int magic, int version, long dbid )
FileHeader.getDbid ( )  :  long
FileHeader.getMagic ( )  :  int
FileHeader.getVersion ( )  :  int
FileHeader.hashCode ( )  :  int
FileHeader.readFields ( DataInput in )  :  void
FileHeader.serialize ( OutputArchive a_, String tag )  :  void
FileHeader.setDbid ( long m_ )  :  void
FileHeader.setMagic ( int m_ )  :  void
FileHeader.setVersion ( int m_ )  :  void
FileHeader.signature ( ) [static]  :  String
FileHeader.toString ( )  :  String
FileHeader.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, FilterList.class
package org.apache.hadoop.hbase.filter
FilterList.equals ( Object obj )  :  boolean
FilterList.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, FirstKeyOnlyFilter.class
package org.apache.hadoop.hbase.filter
FirstKeyOnlyFilter.equals ( Object obj )  :  boolean
FirstKeyOnlyFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, FirstKeyValueMatchingQualifiersFilter.class
package org.apache.hadoop.hbase.filter
FirstKeyValueMatchingQualifiersFilter.FirstKeyValueMatchingQualifiersFilter ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, FourLetterWordMain.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.client
FourLetterWordMain.FourLetterWordMain ( )
FourLetterWordMain.main ( String[ ] args ) [static]  :  void
FourLetterWordMain.send4LetterWord ( String host, int port, String cmd ) [static]  :  String
FourLetterWordMain.send4LetterWord ( String host, int port, String cmd, boolean secure ) [static]  :  String
FourLetterWordMain.send4LetterWord ( String host, int port, String cmd, boolean secure, int timeout ) [static]  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, FuzzyRowFilter.class
package org.apache.hadoop.hbase.filter
FuzzyRowFilter.equals ( Object obj )  :  boolean
FuzzyRowFilter.filterRow ( )  :  boolean
FuzzyRowFilter.hashCode ( )  :  int
FuzzyRowFilter.reset ( )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetACLRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetACLRequest.compareTo ( Object peer_ )  :  int
GetACLRequest.deserialize ( InputArchive a_, String tag )  :  void
GetACLRequest.equals ( Object peer_ )  :  boolean
GetACLRequest.GetACLRequest ( )
GetACLRequest.GetACLRequest ( String path )
GetACLRequest.getPath ( )  :  String
GetACLRequest.hashCode ( )  :  int
GetACLRequest.readFields ( DataInput in )  :  void
GetACLRequest.serialize ( OutputArchive a_, String tag )  :  void
GetACLRequest.setPath ( String m_ )  :  void
GetACLRequest.signature ( ) [static]  :  String
GetACLRequest.toString ( )  :  String
GetACLRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetACLResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetACLResponse.compareTo ( Object peer_ )  :  int
GetACLResponse.deserialize ( InputArchive a_, String tag )  :  void
GetACLResponse.equals ( Object peer_ )  :  boolean
GetACLResponse.getAcl ( )  :  List<ACL>
GetACLResponse.GetACLResponse ( )
GetACLResponse.GetACLResponse ( List<ACL> acl, Stat stat )
GetACLResponse.getStat ( )  :  Stat
GetACLResponse.hashCode ( )  :  int
GetACLResponse.readFields ( DataInput in )  :  void
GetACLResponse.serialize ( OutputArchive a_, String tag )  :  void
GetACLResponse.setAcl ( List<ACL> m_ )  :  void
GetACLResponse.setStat ( Stat m_ )  :  void
GetACLResponse.signature ( ) [static]  :  String
GetACLResponse.toString ( )  :  String
GetACLResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetAllChildrenNumberRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetAllChildrenNumberRequest.compareTo ( Object peer_ )  :  int
GetAllChildrenNumberRequest.deserialize ( InputArchive a_, String tag )  :  void
GetAllChildrenNumberRequest.equals ( Object peer_ )  :  boolean
GetAllChildrenNumberRequest.GetAllChildrenNumberRequest ( )
GetAllChildrenNumberRequest.GetAllChildrenNumberRequest ( String path )
GetAllChildrenNumberRequest.getPath ( )  :  String
GetAllChildrenNumberRequest.hashCode ( )  :  int
GetAllChildrenNumberRequest.readFields ( DataInput in )  :  void
GetAllChildrenNumberRequest.serialize ( OutputArchive a_, String tag )  :  void
GetAllChildrenNumberRequest.setPath ( String m_ )  :  void
GetAllChildrenNumberRequest.signature ( ) [static]  :  String
GetAllChildrenNumberRequest.toString ( )  :  String
GetAllChildrenNumberRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetAllChildrenNumberResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetAllChildrenNumberResponse.compareTo ( Object peer_ )  :  int
GetAllChildrenNumberResponse.deserialize ( InputArchive a_, String tag )  :  void
GetAllChildrenNumberResponse.equals ( Object peer_ )  :  boolean
GetAllChildrenNumberResponse.GetAllChildrenNumberResponse ( )
GetAllChildrenNumberResponse.GetAllChildrenNumberResponse ( int totalNumber )
GetAllChildrenNumberResponse.getTotalNumber ( )  :  int
GetAllChildrenNumberResponse.hashCode ( )  :  int
GetAllChildrenNumberResponse.readFields ( DataInput in )  :  void
GetAllChildrenNumberResponse.serialize ( OutputArchive a_, String tag )  :  void
GetAllChildrenNumberResponse.setTotalNumber ( int m_ )  :  void
GetAllChildrenNumberResponse.signature ( ) [static]  :  String
GetAllChildrenNumberResponse.toString ( )  :  String
GetAllChildrenNumberResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetChildren2Request.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetChildren2Request.compareTo ( Object peer_ )  :  int
GetChildren2Request.deserialize ( InputArchive a_, String tag )  :  void
GetChildren2Request.equals ( Object peer_ )  :  boolean
GetChildren2Request.GetChildren2Request ( )
GetChildren2Request.GetChildren2Request ( String path, boolean watch )
GetChildren2Request.getPath ( )  :  String
GetChildren2Request.getWatch ( )  :  boolean
GetChildren2Request.hashCode ( )  :  int
GetChildren2Request.readFields ( DataInput in )  :  void
GetChildren2Request.serialize ( OutputArchive a_, String tag )  :  void
GetChildren2Request.setPath ( String m_ )  :  void
GetChildren2Request.setWatch ( boolean m_ )  :  void
GetChildren2Request.signature ( ) [static]  :  String
GetChildren2Request.toString ( )  :  String
GetChildren2Request.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetChildren2Response.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetChildren2Response.compareTo ( Object peer_ )  :  int
GetChildren2Response.deserialize ( InputArchive a_, String tag )  :  void
GetChildren2Response.equals ( Object peer_ )  :  boolean
GetChildren2Response.getChildren ( )  :  List<String>
GetChildren2Response.GetChildren2Response ( )
GetChildren2Response.GetChildren2Response ( List<String> children, Stat stat )
GetChildren2Response.getStat ( )  :  Stat
GetChildren2Response.hashCode ( )  :  int
GetChildren2Response.readFields ( DataInput in )  :  void
GetChildren2Response.serialize ( OutputArchive a_, String tag )  :  void
GetChildren2Response.setChildren ( List<String> m_ )  :  void
GetChildren2Response.setStat ( Stat m_ )  :  void
GetChildren2Response.signature ( ) [static]  :  String
GetChildren2Response.toString ( )  :  String
GetChildren2Response.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetChildrenRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetChildrenRequest.compareTo ( Object peer_ )  :  int
GetChildrenRequest.deserialize ( InputArchive a_, String tag )  :  void
GetChildrenRequest.equals ( Object peer_ )  :  boolean
GetChildrenRequest.GetChildrenRequest ( )
GetChildrenRequest.GetChildrenRequest ( String path, boolean watch )
GetChildrenRequest.getPath ( )  :  String
GetChildrenRequest.getWatch ( )  :  boolean
GetChildrenRequest.hashCode ( )  :  int
GetChildrenRequest.readFields ( DataInput in )  :  void
GetChildrenRequest.serialize ( OutputArchive a_, String tag )  :  void
GetChildrenRequest.setPath ( String m_ )  :  void
GetChildrenRequest.setWatch ( boolean m_ )  :  void
GetChildrenRequest.signature ( ) [static]  :  String
GetChildrenRequest.toString ( )  :  String
GetChildrenRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetChildrenResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetChildrenResponse.compareTo ( Object peer_ )  :  int
GetChildrenResponse.deserialize ( InputArchive a_, String tag )  :  void
GetChildrenResponse.equals ( Object peer_ )  :  boolean
GetChildrenResponse.getChildren ( )  :  List<String>
GetChildrenResponse.GetChildrenResponse ( )
GetChildrenResponse.GetChildrenResponse ( List<String> children )
GetChildrenResponse.hashCode ( )  :  int
GetChildrenResponse.readFields ( DataInput in )  :  void
GetChildrenResponse.serialize ( OutputArchive a_, String tag )  :  void
GetChildrenResponse.setChildren ( List<String> m_ )  :  void
GetChildrenResponse.signature ( ) [static]  :  String
GetChildrenResponse.toString ( )  :  String
GetChildrenResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetDataRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetDataRequest.compareTo ( Object peer_ )  :  int
GetDataRequest.deserialize ( InputArchive a_, String tag )  :  void
GetDataRequest.equals ( Object peer_ )  :  boolean
GetDataRequest.GetDataRequest ( )
GetDataRequest.GetDataRequest ( String path, boolean watch )
GetDataRequest.getPath ( )  :  String
GetDataRequest.getWatch ( )  :  boolean
GetDataRequest.hashCode ( )  :  int
GetDataRequest.readFields ( DataInput in )  :  void
GetDataRequest.serialize ( OutputArchive a_, String tag )  :  void
GetDataRequest.setPath ( String m_ )  :  void
GetDataRequest.setWatch ( boolean m_ )  :  void
GetDataRequest.signature ( ) [static]  :  String
GetDataRequest.toString ( )  :  String
GetDataRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetDataResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetDataResponse.compareTo ( Object peer_ )  :  int
GetDataResponse.deserialize ( InputArchive a_, String tag )  :  void
GetDataResponse.equals ( Object peer_ )  :  boolean
GetDataResponse.getData ( )  :  byte[ ]
GetDataResponse.GetDataResponse ( )
GetDataResponse.GetDataResponse ( byte[ ] data, Stat stat )
GetDataResponse.getStat ( )  :  Stat
GetDataResponse.hashCode ( )  :  int
GetDataResponse.readFields ( DataInput in )  :  void
GetDataResponse.serialize ( OutputArchive a_, String tag )  :  void
GetDataResponse.setData ( byte[ ] m_ )  :  void
GetDataResponse.setStat ( Stat m_ )  :  void
GetDataResponse.signature ( ) [static]  :  String
GetDataResponse.toString ( )  :  String
GetDataResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetEphemeralsRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetEphemeralsRequest.compareTo ( Object peer_ )  :  int
GetEphemeralsRequest.deserialize ( InputArchive a_, String tag )  :  void
GetEphemeralsRequest.equals ( Object peer_ )  :  boolean
GetEphemeralsRequest.GetEphemeralsRequest ( )
GetEphemeralsRequest.GetEphemeralsRequest ( String prefixPath )
GetEphemeralsRequest.getPrefixPath ( )  :  String
GetEphemeralsRequest.hashCode ( )  :  int
GetEphemeralsRequest.readFields ( DataInput in )  :  void
GetEphemeralsRequest.serialize ( OutputArchive a_, String tag )  :  void
GetEphemeralsRequest.setPrefixPath ( String m_ )  :  void
GetEphemeralsRequest.signature ( ) [static]  :  String
GetEphemeralsRequest.toString ( )  :  String
GetEphemeralsRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetEphemeralsResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetEphemeralsResponse.compareTo ( Object peer_ )  :  int
GetEphemeralsResponse.deserialize ( InputArchive a_, String tag )  :  void
GetEphemeralsResponse.equals ( Object peer_ )  :  boolean
GetEphemeralsResponse.getEphemerals ( )  :  List<String>
GetEphemeralsResponse.GetEphemeralsResponse ( )
GetEphemeralsResponse.GetEphemeralsResponse ( List<String> ephemerals )
GetEphemeralsResponse.hashCode ( )  :  int
GetEphemeralsResponse.readFields ( DataInput in )  :  void
GetEphemeralsResponse.serialize ( OutputArchive a_, String tag )  :  void
GetEphemeralsResponse.setEphemerals ( List<String> m_ )  :  void
GetEphemeralsResponse.signature ( ) [static]  :  String
GetEphemeralsResponse.toString ( )  :  String
GetEphemeralsResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetMaxChildrenRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetMaxChildrenRequest.compareTo ( Object peer_ )  :  int
GetMaxChildrenRequest.deserialize ( InputArchive a_, String tag )  :  void
GetMaxChildrenRequest.equals ( Object peer_ )  :  boolean
GetMaxChildrenRequest.GetMaxChildrenRequest ( )
GetMaxChildrenRequest.GetMaxChildrenRequest ( String path )
GetMaxChildrenRequest.getPath ( )  :  String
GetMaxChildrenRequest.hashCode ( )  :  int
GetMaxChildrenRequest.readFields ( DataInput in )  :  void
GetMaxChildrenRequest.serialize ( OutputArchive a_, String tag )  :  void
GetMaxChildrenRequest.setPath ( String m_ )  :  void
GetMaxChildrenRequest.signature ( ) [static]  :  String
GetMaxChildrenRequest.toString ( )  :  String
GetMaxChildrenRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetMaxChildrenResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetMaxChildrenResponse.compareTo ( Object peer_ )  :  int
GetMaxChildrenResponse.deserialize ( InputArchive a_, String tag )  :  void
GetMaxChildrenResponse.equals ( Object peer_ )  :  boolean
GetMaxChildrenResponse.getMax ( )  :  int
GetMaxChildrenResponse.GetMaxChildrenResponse ( )
GetMaxChildrenResponse.GetMaxChildrenResponse ( int max )
GetMaxChildrenResponse.hashCode ( )  :  int
GetMaxChildrenResponse.readFields ( DataInput in )  :  void
GetMaxChildrenResponse.serialize ( OutputArchive a_, String tag )  :  void
GetMaxChildrenResponse.setMax ( int m_ )  :  void
GetMaxChildrenResponse.signature ( ) [static]  :  String
GetMaxChildrenResponse.toString ( )  :  String
GetMaxChildrenResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetSASLRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
GetSASLRequest.compareTo ( Object peer_ )  :  int
GetSASLRequest.deserialize ( InputArchive a_, String tag )  :  void
GetSASLRequest.equals ( Object peer_ )  :  boolean
GetSASLRequest.GetSASLRequest ( )
GetSASLRequest.GetSASLRequest ( byte[ ] token )
GetSASLRequest.getToken ( )  :  byte[ ]
GetSASLRequest.hashCode ( )  :  int
GetSASLRequest.readFields ( DataInput in )  :  void
GetSASLRequest.serialize ( OutputArchive a_, String tag )  :  void
GetSASLRequest.setToken ( byte[ ] m_ )  :  void
GetSASLRequest.signature ( ) [static]  :  String
GetSASLRequest.toString ( )  :  String
GetSASLRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GetUserPermissionsRequest.class
package org.apache.hadoop.hbase.security.access
GetUserPermissionsRequest.getFamily ( )  :  byte[ ]
GetUserPermissionsRequest.getNamespace ( )  :  String
GetUserPermissionsRequest.getQualifier ( )  :  byte[ ]
GetUserPermissionsRequest.getTableName ( )  :  TableName
GetUserPermissionsRequest.getUserName ( )  :  String
GetUserPermissionsRequest.newBuilder ( ) [static]  :  GetUserPermissionsRequest.Builder
GetUserPermissionsRequest.newBuilder ( String namespace ) [static]  :  GetUserPermissionsRequest.Builder
GetUserPermissionsRequest.newBuilder ( TableName tableName ) [static]  :  GetUserPermissionsRequest.Builder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, GlobalPermission.class
package org.apache.hadoop.hbase.security.access
GlobalPermission.equals ( Object obj )  :  boolean
GlobalPermission.hashCode ( )  :  int
GlobalPermission.toString ( )  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, HBaseServerException.class
package org.apache.hadoop.hbase
HBaseServerException.HBaseServerException ( )
HBaseServerException.HBaseServerException ( boolean serverOverloaded )
HBaseServerException.HBaseServerException ( boolean serverOverloaded, String message )
HBaseServerException.HBaseServerException ( String message )
HBaseServerException.isServerOverloaded ( )  :  boolean
HBaseServerException.isServerOverloaded ( Throwable t ) [static]  :  boolean
HBaseServerException.setServerOverloaded ( boolean serverOverloaded )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, HBaseSnapshotException.class
package org.apache.hadoop.hbase.snapshot
HBaseSnapshotException.HBaseSnapshotException ( String message, Throwable cause )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, HostProvider.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.client
HostProvider.next ( long p1 ) [abstract]  :  InetSocketAddress
HostProvider.onConnected ( ) [abstract]  :  void
HostProvider.size ( ) [abstract]  :  int
HostProvider.updateServerList ( Collection<InetSocketAddress> p1, InetSocketAddress p2 ) [abstract]  :  boolean

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Id.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.data
Id.compareTo ( Object peer_ )  :  int
Id.deserialize ( InputArchive a_, String tag )  :  void
Id.equals ( Object peer_ )  :  boolean
Id.getId ( )  :  String
Id.getScheme ( )  :  String
Id.hashCode ( )  :  int
Id.Id ( )
Id.Id ( String scheme, String id )
Id.readFields ( DataInput in )  :  void
Id.serialize ( OutputArchive a_, String tag )  :  void
Id.setId ( String m_ )  :  void
Id.setScheme ( String m_ )  :  void
Id.signature ( ) [static]  :  String
Id.toString ( )  :  String
Id.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, InclusiveStopFilter.class
package org.apache.hadoop.hbase.filter
InclusiveStopFilter.equals ( Object obj )  :  boolean
InclusiveStopFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Increment.class
package org.apache.hadoop.hbase.client
Increment.getCellBuilder ( CellBuilderType type )  :  CellBuilder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, IndexBlockEncoding.class
package org.apache.hadoop.hbase.io.encoding
IndexBlockEncoding.getEncodingById ( short indexBlockEncodingId ) [static]  :  IndexBlockEncoding
IndexBlockEncoding.getId ( )  :  short
IndexBlockEncoding.getNameFromId ( short encoderId ) [static]  :  String
IndexBlockEncoding.getNameInBytes ( )  :  byte[ ]
IndexBlockEncoding.valueOf ( String name ) [static]  :  IndexBlockEncoding
IndexBlockEncoding.values ( ) [static]  :  IndexBlockEncoding[ ]
IndexBlockEncoding.writeIdInBytes ( byte[ ] dest, int offset )  :  void
IndexBlockEncoding.writeIdInBytes ( OutputStream stream )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, InvalidACLException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.InvalidACLException.KeeperException.InvalidACLException ( )
KeeperException.InvalidACLException.KeeperException.InvalidACLException ( String path )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, InvalidCallbackException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.InvalidCallbackException.KeeperException.InvalidCallbackException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, InvalidMutationDurabilityException.class
package org.apache.hadoop.hbase.regionserver
InvalidMutationDurabilityException.InvalidMutationDurabilityException ( )
InvalidMutationDurabilityException.InvalidMutationDurabilityException ( String message )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, JsonMapper.class
package org.apache.hadoop.hbase.util
JsonMapper.fromJson ( String json, Class<T> clazz ) [static]  :  T

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, KeeperException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.code ( )  :  KeeperException.Code
KeeperException.create ( int code ) [static]  :  KeeperException *DEPRECATED*
KeeperException.create ( int code, String path ) [static]  :  KeeperException *DEPRECATED*
KeeperException.create ( KeeperException.Code code ) [static]  :  KeeperException
KeeperException.create ( KeeperException.Code code, String path ) [static]  :  KeeperException
KeeperException.getCode ( )  :  int *DEPRECATED*
KeeperException.getMessage ( )  :  String
KeeperException.getPath ( )  :  String
KeeperException.getResults ( )  :  List<OpResult>
KeeperException.KeeperException ( KeeperException.Code code )
KeeperException.setCode ( int code )  :  void *DEPRECATED*

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, KeeperState.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
Watcher.Event.KeeperState.fromInt ( int intValue ) [static]  :  Watcher.Event.KeeperState
Watcher.Event.KeeperState.getIntValue ( )  :  int
Watcher.Event.KeeperState.valueOf ( String name ) [static]  :  Watcher.Event.KeeperState
Watcher.Event.KeeperState.values ( ) [static]  :  Watcher.Event.KeeperState[ ]

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, KeyOnlyFilter.class
package org.apache.hadoop.hbase.filter
KeyOnlyFilter.equals ( Object obj )  :  boolean
KeyOnlyFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, LearnerInfo.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.server.quorum
LearnerInfo.compareTo ( Object peer_ )  :  int
LearnerInfo.deserialize ( InputArchive a_, String tag )  :  void
LearnerInfo.equals ( Object peer_ )  :  boolean
LearnerInfo.getConfigVersion ( )  :  long
LearnerInfo.getProtocolVersion ( )  :  int
LearnerInfo.getServerid ( )  :  long
LearnerInfo.hashCode ( )  :  int
LearnerInfo.LearnerInfo ( )
LearnerInfo.LearnerInfo ( long serverid, int protocolVersion, long configVersion )
LearnerInfo.readFields ( DataInput in )  :  void
LearnerInfo.serialize ( OutputArchive a_, String tag )  :  void
LearnerInfo.setConfigVersion ( long m_ )  :  void
LearnerInfo.setProtocolVersion ( int m_ )  :  void
LearnerInfo.setServerid ( long m_ )  :  void
LearnerInfo.signature ( ) [static]  :  String
LearnerInfo.toString ( )  :  String
LearnerInfo.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, LogChopper.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.server.util
LogChopper.chop ( InputStream is, OutputStream os, long zxid ) [static]  :  boolean
LogChopper.LogChopper ( )
LogChopper.main ( String[ ] args ) [static]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, LogEntry.class
package org.apache.hadoop.hbase.client
LogEntry.LogEntry ( )
LogEntry.toJsonPrettyPrint ( ) [abstract]  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, LogQueryFilter.class
package org.apache.hadoop.hbase.client
LogQueryFilter.equals ( Object o )  :  boolean
LogQueryFilter.getClientAddress ( )  :  String
LogQueryFilter.getFilterByOperator ( )  :  LogQueryFilter.FilterByOperator
LogQueryFilter.getLimit ( )  :  int
LogQueryFilter.getRegionName ( )  :  String
LogQueryFilter.getTableName ( )  :  String
LogQueryFilter.getType ( )  :  LogQueryFilter.Type
LogQueryFilter.getUserName ( )  :  String
LogQueryFilter.hashCode ( )  :  int
LogQueryFilter.LogQueryFilter ( )
LogQueryFilter.setClientAddress ( String clientAddress )  :  void
LogQueryFilter.setFilterByOperator ( LogQueryFilter.FilterByOperator filterByOperator )  :  void
LogQueryFilter.setLimit ( int limit )  :  void
LogQueryFilter.setRegionName ( String regionName )  :  void
LogQueryFilter.setTableName ( String tableName )  :  void
LogQueryFilter.setType ( LogQueryFilter.Type type )  :  void
LogQueryFilter.setUserName ( String userName )  :  void
LogQueryFilter.toString ( )  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, MarshallingErrorException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.MarshallingErrorException.KeeperException.MarshallingErrorException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, MultiCallback.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
AsyncCallback.MultiCallback.processResult ( int p1, String p2, Object p3, List<OpResult> p4 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, MultiHeader.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
MultiHeader.compareTo ( Object peer_ )  :  int
MultiHeader.deserialize ( InputArchive a_, String tag )  :  void
MultiHeader.equals ( Object peer_ )  :  boolean
MultiHeader.getDone ( )  :  boolean
MultiHeader.getErr ( )  :  int
MultiHeader.getType ( )  :  int
MultiHeader.hashCode ( )  :  int
MultiHeader.MultiHeader ( )
MultiHeader.MultiHeader ( int type, boolean done, int err )
MultiHeader.readFields ( DataInput in )  :  void
MultiHeader.serialize ( OutputArchive a_, String tag )  :  void
MultiHeader.setDone ( boolean m_ )  :  void
MultiHeader.setErr ( int m_ )  :  void
MultiHeader.setType ( int m_ )  :  void
MultiHeader.signature ( ) [static]  :  String
MultiHeader.toString ( )  :  String
MultiHeader.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, MultipleColumnPrefixFilter.class
package org.apache.hadoop.hbase.filter
MultipleColumnPrefixFilter.equals ( Object obj )  :  boolean
MultipleColumnPrefixFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, MultiRowRangeFilter.class
package org.apache.hadoop.hbase.filter
MultiRowRangeFilter.equals ( Object obj )  :  boolean
MultiRowRangeFilter.hashCode ( )  :  int
MultiRowRangeFilter.MultiRowRangeFilter ( byte[ ][ ] rowKeyPrefixes )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, MultiTxn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
MultiTxn.compareTo ( Object peer_ )  :  int
MultiTxn.deserialize ( InputArchive a_, String tag )  :  void
MultiTxn.equals ( Object peer_ )  :  boolean
MultiTxn.getTxns ( )  :  List<Txn>
MultiTxn.hashCode ( )  :  int
MultiTxn.MultiTxn ( )
MultiTxn.MultiTxn ( List<Txn> txns )
MultiTxn.readFields ( DataInput in )  :  void
MultiTxn.serialize ( OutputArchive a_, String tag )  :  void
MultiTxn.setTxns ( List<Txn> m_ )  :  void
MultiTxn.signature ( ) [static]  :  String
MultiTxn.toString ( )  :  String
MultiTxn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Mutation.class
package org.apache.hadoop.hbase.client
Mutation.getCellBuilder ( )  :  CellBuilder
Mutation.getCellBuilder ( CellBuilderType cellBuilderType, Cell.Type cellType )  :  CellBuilder
Mutation.getCellBuilder ( CellBuilderType p1 ) [abstract]  :  CellBuilder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, NamespacePermission.class
package org.apache.hadoop.hbase.security.access
NamespacePermission.equals ( Object obj )  :  boolean
NamespacePermission.equalsExceptActions ( Object obj )  :  boolean
NamespacePermission.getNamespace ( )  :  String
NamespacePermission.hashCode ( )  :  int
NamespacePermission.implies ( String namespace, Permission.Action action )  :  boolean
NamespacePermission.rawExpression ( )  :  String
NamespacePermission.readFields ( DataInput in )  :  void
NamespacePermission.toString ( )  :  String
NamespacePermission.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, NewConfigNoQuorum.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.NewConfigNoQuorum.KeeperException.NewConfigNoQuorum ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, NoAuthException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.NoAuthException.KeeperException.NoAuthException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, NoChildrenForEphemeralsException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.NoChildrenForEphemeralsException.KeeperException.NoChildrenForEphemeralsException ( )
KeeperException.NoChildrenForEphemeralsException.KeeperException.NoChildrenForEphemeralsException ( String path )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, NodeExistsException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.NodeExistsException.KeeperException.NodeExistsException ( )
KeeperException.NodeExistsException.KeeperException.NodeExistsException ( String path )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, NoNodeException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.NoNodeException.KeeperException.NoNodeException ( )
KeeperException.NoNodeException.KeeperException.NoNodeException ( String path )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, NormalizeTableFilterParams.class
package org.apache.hadoop.hbase.client
NormalizeTableFilterParams.getNamespace ( )  :  String
NormalizeTableFilterParams.getRegex ( )  :  String
NormalizeTableFilterParams.getTableNames ( )  :  List<TableName>

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, NotEmptyException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.NotEmptyException.KeeperException.NotEmptyException ( )
KeeperException.NotEmptyException.KeeperException.NotEmptyException ( String path )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, NotReadOnlyException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.NotReadOnlyException.KeeperException.NotReadOnlyException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, NoWatcherException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.NoWatcherException.KeeperException.NoWatcherException ( )
KeeperException.NoWatcherException.KeeperException.NoWatcherException ( String path )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, OnlineLogRecord.class
package org.apache.hadoop.hbase.client
OnlineLogRecord.equals ( Object o )  :  boolean
OnlineLogRecord.getBlockBytesScanned ( )  :  long
OnlineLogRecord.getCallDetails ( )  :  String
OnlineLogRecord.getClientAddress ( )  :  String
OnlineLogRecord.getConnectionAttributes ( )  :  Map<String,byte[ ]>
OnlineLogRecord.getMethodName ( )  :  String
OnlineLogRecord.getMultiGetsCount ( )  :  int
OnlineLogRecord.getMultiMutationsCount ( )  :  int
OnlineLogRecord.getMultiServiceCalls ( )  :  int
OnlineLogRecord.getParam ( )  :  String
OnlineLogRecord.getProcessingTime ( )  :  int
OnlineLogRecord.getQueueTime ( )  :  int
OnlineLogRecord.getRegionName ( )  :  String
OnlineLogRecord.getRequestAttributes ( )  :  Map<String,byte[ ]>
OnlineLogRecord.getResponseSize ( )  :  long
OnlineLogRecord.getScan ( )  :  Optional<Scan>
OnlineLogRecord.getServerClass ( )  :  String
OnlineLogRecord.getStartTime ( )  :  long
OnlineLogRecord.getUserName ( )  :  String
OnlineLogRecord.hashCode ( )  :  int
OnlineLogRecord.toJsonPrettyPrint ( )  :  String
OnlineLogRecord.toString ( )  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, OperationTimeoutException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.OperationTimeoutException.KeeperException.OperationTimeoutException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, PageFilter.class
package org.apache.hadoop.hbase.filter
PageFilter.equals ( Object obj )  :  boolean
PageFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Permission.class
package org.apache.hadoop.hbase.security.access
Permission.equalsExceptActions ( Object obj )  :  boolean
Permission.getAccessScope ( )  :  Permission.Scope
Permission.newBuilder ( ) [static]  :  Permission.Builder
Permission.newBuilder ( String namespace ) [static]  :  Permission.Builder
Permission.newBuilder ( TableName tableName ) [static]  :  Permission.Builder
Permission.rawExpression ( )  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, PleaseRestartMasterException.class
package org.apache.hadoop.hbase
PleaseRestartMasterException.PleaseRestartMasterException ( String s )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, PrefixFilter.class
package org.apache.hadoop.hbase.filter
PrefixFilter.equals ( Object obj )  :  boolean
PrefixFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, PurgeTxnLog.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.server
PurgeTxnLog.main ( String[ ] args ) [static]  :  void
PurgeTxnLog.purge ( File dataDir, File snapDir, int num ) [static]  :  void
PurgeTxnLog.PurgeTxnLog ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Put.class
package org.apache.hadoop.hbase.client
Put.getCellBuilder ( CellBuilderType type )  :  CellBuilder
Put.setPriority ( int p1 )  :  OperationWithAttributes
Put.setPriority ( int priority )  :  Put

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, QualifierFilter.class
package org.apache.hadoop.hbase.filter
QualifierFilter.equals ( Object obj )  :  boolean
QualifierFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, QuorumAuthPacket.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.server.quorum
QuorumAuthPacket.compareTo ( Object peer_ )  :  int
QuorumAuthPacket.deserialize ( InputArchive a_, String tag )  :  void
QuorumAuthPacket.equals ( Object peer_ )  :  boolean
QuorumAuthPacket.getMagic ( )  :  long
QuorumAuthPacket.getStatus ( )  :  int
QuorumAuthPacket.getToken ( )  :  byte[ ]
QuorumAuthPacket.hashCode ( )  :  int
QuorumAuthPacket.QuorumAuthPacket ( )
QuorumAuthPacket.QuorumAuthPacket ( long magic, int status, byte[ ] token )
QuorumAuthPacket.readFields ( DataInput in )  :  void
QuorumAuthPacket.serialize ( OutputArchive a_, String tag )  :  void
QuorumAuthPacket.setMagic ( long m_ )  :  void
QuorumAuthPacket.setStatus ( int m_ )  :  void
QuorumAuthPacket.setToken ( byte[ ] m_ )  :  void
QuorumAuthPacket.signature ( ) [static]  :  String
QuorumAuthPacket.toString ( )  :  String
QuorumAuthPacket.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, QuorumPacket.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.server.quorum
QuorumPacket.compareTo ( Object peer_ )  :  int
QuorumPacket.deserialize ( InputArchive a_, String tag )  :  void
QuorumPacket.equals ( Object peer_ )  :  boolean
QuorumPacket.getAuthinfo ( )  :  List<Id>
QuorumPacket.getData ( )  :  byte[ ]
QuorumPacket.getType ( )  :  int
QuorumPacket.getZxid ( )  :  long
QuorumPacket.hashCode ( )  :  int
QuorumPacket.QuorumPacket ( )
QuorumPacket.QuorumPacket ( int type, long zxid, byte[ ] data, List<Id> authinfo )
QuorumPacket.readFields ( DataInput in )  :  void
QuorumPacket.serialize ( OutputArchive a_, String tag )  :  void
QuorumPacket.setAuthinfo ( List<Id> m_ )  :  void
QuorumPacket.setData ( byte[ ] m_ )  :  void
QuorumPacket.setType ( int m_ )  :  void
QuorumPacket.setZxid ( long m_ )  :  void
QuorumPacket.signature ( ) [static]  :  String
QuorumPacket.toString ( )  :  String
QuorumPacket.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, QuorumPeerConfig.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.server.quorum
QuorumPeerConfig.areLocalSessionsEnabled ( )  :  boolean
QuorumPeerConfig.checkValidity ( )  :  void
QuorumPeerConfig.configureSSLAuth ( ) [static]  :  void
QuorumPeerConfig.deleteFile ( String filename ) [static]  :  void
QuorumPeerConfig.editStaticConfig ( String configFileStr, String dynamicFileStr, boolean eraseClientPortAddress ) [static]  :  void
QuorumPeerConfig.getClientPortAddress ( )  :  InetSocketAddress
QuorumPeerConfig.getClientPortListenBacklog ( )  :  int
QuorumPeerConfig.getConfigFilename ( )  :  String
QuorumPeerConfig.getConnectToLearnerMasterLimit ( )  :  int
QuorumPeerConfig.getDataDir ( )  :  File
QuorumPeerConfig.getDataLogDir ( )  :  File
QuorumPeerConfig.getElectionAlg ( )  :  int
QuorumPeerConfig.getElectionPort ( )  :  int
QuorumPeerConfig.getInitialConfig ( )  :  String
QuorumPeerConfig.getInitLimit ( )  :  int
QuorumPeerConfig.getJvmPauseInfoThresholdMs ( )  :  long
QuorumPeerConfig.getJvmPauseSleepTimeMs ( )  :  long
QuorumPeerConfig.getJvmPauseWarnThresholdMs ( )  :  long
QuorumPeerConfig.getLastSeenQuorumVerifier ( )  :  QuorumVerifier
QuorumPeerConfig.getMaxClientCnxns ( )  :  int
QuorumPeerConfig.getMaxSessionTimeout ( )  :  int
QuorumPeerConfig.getMetricsProviderClassName ( )  :  String
QuorumPeerConfig.getMetricsProviderConfiguration ( )  :  Properties
QuorumPeerConfig.getMinSessionTimeout ( )  :  int
QuorumPeerConfig.getMultiAddressReachabilityCheckTimeoutMs ( )  :  int
QuorumPeerConfig.getObserverMasterPort ( )  :  int
QuorumPeerConfig.getPeerType ( )  :  QuorumPeer.LearnerType
QuorumPeerConfig.getPurgeInterval ( )  :  int
QuorumPeerConfig.getQuorumListenOnAllIPs ( )  :  Boolean
QuorumPeerConfig.getQuorumVerifier ( )  :  QuorumVerifier
QuorumPeerConfig.getSecureClientPortAddress ( )  :  InetSocketAddress
QuorumPeerConfig.getServerId ( )  :  long
QuorumPeerConfig.getServers ( )  :  Map<Long,QuorumPeer.QuorumServer>
QuorumPeerConfig.getSnapRetainCount ( )  :  int
QuorumPeerConfig.getSyncEnabled ( )  :  boolean
QuorumPeerConfig.getSyncLimit ( )  :  int
QuorumPeerConfig.getTickTime ( )  :  int
QuorumPeerConfig.getVersionFromFilename ( String filename ) [static]  :  String
QuorumPeerConfig.isDistributed ( )  :  boolean
QuorumPeerConfig.isJvmPauseMonitorToRun ( )  :  boolean
QuorumPeerConfig.isLocalSessionsUpgradingEnabled ( )  :  boolean
QuorumPeerConfig.isMultiAddressEnabled ( )  :  boolean
QuorumPeerConfig.isMultiAddressReachabilityCheckEnabled ( )  :  boolean
QuorumPeerConfig.isReconfigEnabled ( ) [static]  :  boolean
QuorumPeerConfig.isSslQuorum ( )  :  boolean
QuorumPeerConfig.isStandaloneEnabled ( ) [static]  :  boolean
QuorumPeerConfig.parse ( String path )  :  void
QuorumPeerConfig.parseDynamicConfig ( Properties dynamicConfigProp, int eAlg, boolean warnings, boolean configBackwardCompatibilityMode, String oraclePath ) [static]  :  QuorumVerifier
QuorumPeerConfig.parseProperties ( Properties zkProp )  :  void
QuorumPeerConfig.QuorumPeerConfig ( )
QuorumPeerConfig.setReconfigEnabled ( boolean enabled ) [static]  :  void
QuorumPeerConfig.setStandaloneEnabled ( boolean enabled ) [static]  :  void
QuorumPeerConfig.shouldUsePortUnification ( )  :  boolean
QuorumPeerConfig.writeDynamicConfig ( String dynamicConfigFilename, QuorumVerifier qv, boolean needKeepVersion ) [static]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, QuorumPeerMain.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.server.quorum
QuorumPeerMain.close ( )  :  void
QuorumPeerMain.getQuorumPeer ( )  :  QuorumPeer
QuorumPeerMain.initializeAndRun ( String[ ] args )  :  void
QuorumPeerMain.main ( String[ ] args ) [static]  :  void
QuorumPeerMain.QuorumPeerMain ( )
QuorumPeerMain.runFromConfig ( QuorumPeerConfig config )  :  void
QuorumPeerMain.toString ( )  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, QuotaExceededException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.QuotaExceededException.KeeperException.QuotaExceededException ( )
KeeperException.QuotaExceededException.KeeperException.QuotaExceededException ( String path )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, QuotaFilter.class
package org.apache.hadoop.hbase.quotas
QuotaFilter.getRegionServerFilter ( )  :  String
QuotaFilter.setRegionServerFilter ( String regex )  :  QuotaFilter

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, QuotaSettings.class
package org.apache.hadoop.hbase.quotas
QuotaSettings.getRegionServer ( )  :  String
QuotaSettings.QuotaSettings ( String userName, TableName tableName, String namespace, String regionServer )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, QuotaSettingsFactory.class
package org.apache.hadoop.hbase.quotas
QuotaSettingsFactory.fromTableThrottles ( TableName tableName, QuotaProtos.Throttle throttle ) [static]  :  List<ThrottleSettings>
QuotaSettingsFactory.fromThrottle ( String userName, TableName tableName, String namespace, String regionServer, QuotaProtos.Throttle throttle ) [static]  :  List<ThrottleSettings>
QuotaSettingsFactory.throttleNamespace ( String namespace, ThrottleType type, long limit, TimeUnit timeUnit, QuotaScope scope ) [static]  :  QuotaSettings
QuotaSettingsFactory.throttleRegionServer ( String regionServer, ThrottleType type, long limit, TimeUnit timeUnit ) [static]  :  QuotaSettings
QuotaSettingsFactory.throttleTable ( TableName tableName, ThrottleType type, long limit, TimeUnit timeUnit, QuotaScope scope ) [static]  :  QuotaSettings
QuotaSettingsFactory.throttleUser ( String userName, String namespace, ThrottleType type, long limit, TimeUnit timeUnit, QuotaScope scope ) [static]  :  QuotaSettings
QuotaSettingsFactory.throttleUser ( String userName, TableName tableName, ThrottleType type, long limit, TimeUnit timeUnit, QuotaScope scope ) [static]  :  QuotaSettings
QuotaSettingsFactory.throttleUser ( String userName, ThrottleType type, long limit, TimeUnit timeUnit, QuotaScope scope ) [static]  :  QuotaSettings
QuotaSettingsFactory.unthrottleNamespaceByThrottleType ( String namespace, ThrottleType type ) [static]  :  QuotaSettings
QuotaSettingsFactory.unthrottleRegionServer ( String regionServer ) [static]  :  QuotaSettings
QuotaSettingsFactory.unthrottleRegionServerByThrottleType ( String regionServer, ThrottleType type ) [static]  :  QuotaSettings
QuotaSettingsFactory.unthrottleTableByThrottleType ( TableName tableName, ThrottleType type ) [static]  :  QuotaSettings
QuotaSettingsFactory.unthrottleUserByThrottleType ( String userName, String namespace, ThrottleType type ) [static]  :  QuotaSettings
QuotaSettingsFactory.unthrottleUserByThrottleType ( String userName, TableName tableName, ThrottleType type ) [static]  :  QuotaSettings
QuotaSettingsFactory.unthrottleUserByThrottleType ( String userName, ThrottleType type ) [static]  :  QuotaSettings

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RandomRowFilter.class
package org.apache.hadoop.hbase.filter
RandomRowFilter.equals ( Object obj )  :  boolean
RandomRowFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ReconfigDisabledException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.ReconfigDisabledException.KeeperException.ReconfigDisabledException ( )
KeeperException.ReconfigDisabledException.KeeperException.ReconfigDisabledException ( String path )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ReconfigInProgress.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.ReconfigInProgress.KeeperException.ReconfigInProgress ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ReconfigRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
ReconfigRequest.compareTo ( Object peer_ )  :  int
ReconfigRequest.deserialize ( InputArchive a_, String tag )  :  void
ReconfigRequest.equals ( Object peer_ )  :  boolean
ReconfigRequest.getCurConfigId ( )  :  long
ReconfigRequest.getJoiningServers ( )  :  String
ReconfigRequest.getLeavingServers ( )  :  String
ReconfigRequest.getNewMembers ( )  :  String
ReconfigRequest.hashCode ( )  :  int
ReconfigRequest.readFields ( DataInput in )  :  void
ReconfigRequest.ReconfigRequest ( )
ReconfigRequest.ReconfigRequest ( String joiningServers, String leavingServers, String newMembers, long curConfigId )
ReconfigRequest.serialize ( OutputArchive a_, String tag )  :  void
ReconfigRequest.setCurConfigId ( long m_ )  :  void
ReconfigRequest.setJoiningServers ( String m_ )  :  void
ReconfigRequest.setLeavingServers ( String m_ )  :  void
ReconfigRequest.setNewMembers ( String m_ )  :  void
ReconfigRequest.signature ( ) [static]  :  String
ReconfigRequest.toString ( )  :  String
ReconfigRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Record.class
package org.apache.hadoop.hbase.shaded.org.apache.jute
Record.deserialize ( InputArchive p1, String p2 ) [abstract]  :  void
Record.serialize ( OutputArchive p1, String p2 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RegionInfo.class
package org.apache.hadoop.hbase.client
RegionInfo.compareTo ( Object p1 )  :  int
RegionInfo.compareTo ( RegionInfo other )  :  int
RegionInfo.getRegionNameAsString ( byte[ ] regionName ) [static]  :  String
RegionInfo.getRegionNameAsString ( RegionInfo ri, byte[ ] regionName ) [static]  :  String
RegionInfo.isAdjacent ( RegionInfo other )  :  boolean
RegionInfo.isDegenerate ( )  :  boolean
RegionInfo.isFirst ( )  :  boolean
RegionInfo.isLast ( )  :  boolean
RegionInfo.isNext ( RegionInfo after )  :  boolean
RegionInfo.isOverlap ( RegionInfo other )  :  boolean
RegionInfo.parseRegionNameOrReturnNull ( byte[ ] regionName ) [static]  :  byte[ ][ ]

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RegionLocator.class
package org.apache.hadoop.hbase.client
RegionLocator.clearRegionLocationCache ( ) [abstract]  :  void
RegionLocator.getRegionLocation ( byte[ ] p1, int p2, boolean p3 ) [abstract]  :  HRegionLocation
RegionLocator.getRegionLocation ( byte[ ] row, int replicaId )  :  HRegionLocation
RegionLocator.getRegionLocations ( byte[ ] p1, boolean p2 ) [abstract]  :  List<HRegionLocation>
RegionLocator.getRegionLocations ( byte[ ] row )  :  List<HRegionLocation>

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RegionMetrics.class
package org.apache.hadoop.hbase
RegionMetrics.getBlocksLocalWeight ( ) [abstract]  :  long
RegionMetrics.getBlocksLocalWithSsdWeight ( ) [abstract]  :  long
RegionMetrics.getBlocksTotalWeight ( ) [abstract]  :  long
RegionMetrics.getCompactionState ( ) [abstract]  :  CompactionState
RegionMetrics.getCpRequestCount ( ) [abstract]  :  long
RegionMetrics.getCurrentRegionCachedRatio ( ) [abstract]  :  float
RegionMetrics.getDataLocalityForSsd ( ) [abstract]  :  float
RegionMetrics.getMaxCompactedStoreFileRefCount ( ) [abstract]  :  int
RegionMetrics.getRegionSizeMB ( ) [abstract]  :  Size
RegionMetrics.getStoreRefCount ( ) [abstract]  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RemoteWithExtrasException.class
package org.apache.hadoop.hbase.ipc
RemoteWithExtrasException.isServerOverloaded ( )  :  boolean
RemoteWithExtrasException.RemoteWithExtrasException ( String className, String msg, boolean doNotRetry, boolean serverOverloaded )
RemoteWithExtrasException.RemoteWithExtrasException ( String className, String msg, String hostname, int port, boolean doNotRetry, boolean serverOverloaded )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RemoveWatchesRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
RemoveWatchesRequest.compareTo ( Object peer_ )  :  int
RemoveWatchesRequest.deserialize ( InputArchive a_, String tag )  :  void
RemoveWatchesRequest.equals ( Object peer_ )  :  boolean
RemoveWatchesRequest.getPath ( )  :  String
RemoveWatchesRequest.getType ( )  :  int
RemoveWatchesRequest.hashCode ( )  :  int
RemoveWatchesRequest.readFields ( DataInput in )  :  void
RemoveWatchesRequest.RemoveWatchesRequest ( )
RemoveWatchesRequest.RemoveWatchesRequest ( String path, int type )
RemoveWatchesRequest.serialize ( OutputArchive a_, String tag )  :  void
RemoveWatchesRequest.setPath ( String m_ )  :  void
RemoveWatchesRequest.setType ( int m_ )  :  void
RemoveWatchesRequest.signature ( ) [static]  :  String
RemoveWatchesRequest.toString ( )  :  String
RemoveWatchesRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ReplicationLoadSink.class
package org.apache.hadoop.hbase.replication
ReplicationLoadSink.getTimestampStarted ( )  :  long
ReplicationLoadSink.getTotalOpsProcessed ( )  :  long
ReplicationLoadSink.newBuilder ( ) [static]  :  ReplicationLoadSink.ReplicationLoadSinkBuilder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ReplicationLoadSource.class
package org.apache.hadoop.hbase.replication
ReplicationLoadSource.getEditsRead ( )  :  long
ReplicationLoadSource.getOPsShipped ( )  :  long
ReplicationLoadSource.getQueueId ( )  :  String
ReplicationLoadSource.getTimeStampOfNextToReplicate ( )  :  long
ReplicationLoadSource.hasEditsSinceRestart ( )  :  boolean
ReplicationLoadSource.isRecovered ( )  :  boolean
ReplicationLoadSource.isRunning ( )  :  boolean
ReplicationLoadSource.newBuilder ( ) [static]  :  ReplicationLoadSource.ReplicationLoadSourceBuilder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ReplicationPeerConfig.class
package org.apache.hadoop.hbase.replication
ReplicationPeerConfig.getRemoteWALDir ( )  :  String
ReplicationPeerConfig.isSerial ( )  :  boolean
ReplicationPeerConfig.isSyncReplication ( )  :  boolean
ReplicationPeerConfig.needToReplicate ( TableName table, byte[ ] family )  :  boolean

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ReplicationPeerConfigBuilder.class
package org.apache.hadoop.hbase.replication
ReplicationPeerConfigBuilder.removeConfiguration ( String p1 ) [abstract]  :  ReplicationPeerConfigBuilder
ReplicationPeerConfigBuilder.setRemoteWALDir ( String p1 ) [abstract]  :  ReplicationPeerConfigBuilder
ReplicationPeerConfigBuilder.setSerial ( boolean p1 ) [abstract]  :  ReplicationPeerConfigBuilder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ReplicationPeerDescription.class
package org.apache.hadoop.hbase.replication
ReplicationPeerDescription.getSyncReplicationState ( )  :  SyncReplicationState
ReplicationPeerDescription.ReplicationPeerDescription ( String id, boolean enabled, ReplicationPeerConfig config, SyncReplicationState syncReplicationState )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ReplyHeader.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
ReplyHeader.compareTo ( Object peer_ )  :  int
ReplyHeader.deserialize ( InputArchive a_, String tag )  :  void
ReplyHeader.equals ( Object peer_ )  :  boolean
ReplyHeader.getErr ( )  :  int
ReplyHeader.getXid ( )  :  int
ReplyHeader.getZxid ( )  :  long
ReplyHeader.hashCode ( )  :  int
ReplyHeader.readFields ( DataInput in )  :  void
ReplyHeader.ReplyHeader ( )
ReplyHeader.ReplyHeader ( int xid, long zxid, int err )
ReplyHeader.serialize ( OutputArchive a_, String tag )  :  void
ReplyHeader.setErr ( int m_ )  :  void
ReplyHeader.setXid ( int m_ )  :  void
ReplyHeader.setZxid ( long m_ )  :  void
ReplyHeader.signature ( ) [static]  :  String
ReplyHeader.toString ( )  :  String
ReplyHeader.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RequestHeader.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
RequestHeader.compareTo ( Object peer_ )  :  int
RequestHeader.deserialize ( InputArchive a_, String tag )  :  void
RequestHeader.equals ( Object peer_ )  :  boolean
RequestHeader.getType ( )  :  int
RequestHeader.getXid ( )  :  int
RequestHeader.hashCode ( )  :  int
RequestHeader.readFields ( DataInput in )  :  void
RequestHeader.RequestHeader ( )
RequestHeader.RequestHeader ( int xid, int type )
RequestHeader.serialize ( OutputArchive a_, String tag )  :  void
RequestHeader.setType ( int m_ )  :  void
RequestHeader.setXid ( int m_ )  :  void
RequestHeader.signature ( ) [static]  :  String
RequestHeader.toString ( )  :  String
RequestHeader.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RestoreSnapshotException.class
package org.apache.hadoop.hbase.snapshot
RestoreSnapshotException.RestoreSnapshotException ( String message, Throwable cause )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Result.class
package org.apache.hadoop.hbase.client
Result.compareResults ( Result res1, Result res2, boolean verbose ) [static]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RowFilter.class
package org.apache.hadoop.hbase.filter
RowFilter.equals ( Object obj )  :  boolean
RowFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RowRange.class
package org.apache.hadoop.hbase.filter
MultiRowRangeFilter.RowRange.compareTo ( MultiRowRangeFilter.BasicRowRange p1 )  :  int
MultiRowRangeFilter.RowRange.equals ( Object p1 )  :  boolean
MultiRowRangeFilter.RowRange.getComparisonData ( )  :  byte[ ]
MultiRowRangeFilter.RowRange.hashCode ( )  :  int
MultiRowRangeFilter.RowRange.isAscendingOrder ( )  :  boolean
MultiRowRangeFilter.RowRange.isSearchRowInclusive ( )  :  boolean

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RpcThrottlingException.class
package org.apache.hadoop.hbase.quotas
RpcThrottlingException.stringFromMillis ( long millis ) [static]  :  String
RpcThrottlingException.throwReadCapacityUnitExceeded ( long waitInterval ) [static]  :  void
RpcThrottlingException.throwRequestCapacityUnitExceeded ( long waitInterval ) [static]  :  void
RpcThrottlingException.throwWriteCapacityUnitExceeded ( long waitInterval ) [static]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RSGroupInfo.class
package org.apache.hadoop.hbase.rsgroup
RSGroupInfo.getConfiguration ( )  :  Map<String,String>
RSGroupInfo.removeConfiguration ( String key )  :  void
RSGroupInfo.setConfiguration ( String key, String value )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, RuntimeInconsistencyException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.RuntimeInconsistencyException.KeeperException.RuntimeInconsistencyException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Scan.class
package org.apache.hadoop.hbase.client
Scan.setStartStopRowForPrefixScan ( byte[ ] rowPrefix )  :  Scan

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ServerAdminClient.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
ServerAdminClient.dump ( String host, int port ) [static]  :  void
ServerAdminClient.getTraceMask ( String host, int port ) [static]  :  void
ServerAdminClient.kill ( String host, int port ) [static]  :  void
ServerAdminClient.main ( String[ ] args ) [static]  :  void
ServerAdminClient.ruok ( String host, int port ) [static]  :  void
ServerAdminClient.ServerAdminClient ( )
ServerAdminClient.setTraceMask ( String host, int port, String traceMaskStr ) [static]  :  void
ServerAdminClient.stat ( String host, int port ) [static]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ServerConfig.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.server
ServerConfig.getClientPortAddress ( )  :  InetSocketAddress
ServerConfig.getClientPortListenBacklog ( )  :  int
ServerConfig.getDataDir ( )  :  File
ServerConfig.getDataLogDir ( )  :  File
ServerConfig.getJvmPauseInfoThresholdMs ( )  :  long
ServerConfig.getJvmPauseSleepTimeMs ( )  :  long
ServerConfig.getJvmPauseWarnThresholdMs ( )  :  long
ServerConfig.getMaxClientCnxns ( )  :  int
ServerConfig.getMaxSessionTimeout ( )  :  int
ServerConfig.getMetricsProviderClassName ( )  :  String
ServerConfig.getMetricsProviderConfiguration ( )  :  Properties
ServerConfig.getMinSessionTimeout ( )  :  int
ServerConfig.getSecureClientPortAddress ( )  :  InetSocketAddress
ServerConfig.getTickTime ( )  :  int
ServerConfig.isJvmPauseMonitorToRun ( )  :  boolean
ServerConfig.parse ( String path )  :  void
ServerConfig.parse ( String[ ] args )  :  void
ServerConfig.readFrom ( QuorumPeerConfig config )  :  void
ServerConfig.ServerConfig ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ServerMetrics.class
package org.apache.hadoop.hbase
ServerMetrics.getReadRequestsCount ( ) [abstract]  :  long
ServerMetrics.getRegionCachedInfo ( ) [abstract]  :  Map<String,Integer>
ServerMetrics.getReplicationLoadSourceMap ( ) [abstract]  :  Map<String,List<ReplicationLoadSource>>
ServerMetrics.getTasks ( ) [abstract]  :  List<ServerTask>
ServerMetrics.getUserMetrics ( ) [abstract]  :  Map<byte[ ],UserMetrics>
ServerMetrics.getVersion ( )  :  String
ServerMetrics.getVersionNumber ( )  :  int
ServerMetrics.getWriteRequestsCount ( ) [abstract]  :  long

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ServerName.class
package org.apache.hadoop.hbase
ServerName.getHostnameLowerCase ( )  :  String
ServerName.getStartCode ( )  :  long
ServerName.valueOf ( Address address, long startCode ) [static]  :  ServerName

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ServerTask.class
package org.apache.hadoop.hbase
ServerTask.getCompletionTime ( ) [abstract]  :  long
ServerTask.getDescription ( ) [abstract]  :  String
ServerTask.getStartTime ( ) [abstract]  :  long
ServerTask.getState ( ) [abstract]  :  ServerTask.State
ServerTask.getStatus ( ) [abstract]  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ServerTooBusyException.class
package org.apache.hadoop.hbase.ipc
ServerTooBusyException.ServerTooBusyException ( Address address, long count )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ServerType.class
package org.apache.hadoop.hbase.client
ServerType.valueOf ( String name ) [static]  :  ServerType
ServerType.values ( ) [static]  :  ServerType[ ]

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ServiceCaller.class
package org.apache.hadoop.hbase.client
ServiceCaller<S,R>.call ( S p1, RpcController p2, RpcCallback<R> p3 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SessionExpiredException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.SessionExpiredException.KeeperException.SessionExpiredException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SessionMovedException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.SessionMovedException.KeeperException.SessionMovedException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SetACLRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
SetACLRequest.compareTo ( Object peer_ )  :  int
SetACLRequest.deserialize ( InputArchive a_, String tag )  :  void
SetACLRequest.equals ( Object peer_ )  :  boolean
SetACLRequest.getAcl ( )  :  List<ACL>
SetACLRequest.getPath ( )  :  String
SetACLRequest.getVersion ( )  :  int
SetACLRequest.hashCode ( )  :  int
SetACLRequest.readFields ( DataInput in )  :  void
SetACLRequest.serialize ( OutputArchive a_, String tag )  :  void
SetACLRequest.setAcl ( List<ACL> m_ )  :  void
SetACLRequest.SetACLRequest ( )
SetACLRequest.SetACLRequest ( String path, List<ACL> acl, int version )
SetACLRequest.setPath ( String m_ )  :  void
SetACLRequest.setVersion ( int m_ )  :  void
SetACLRequest.signature ( ) [static]  :  String
SetACLRequest.toString ( )  :  String
SetACLRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SetACLResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
SetACLResponse.compareTo ( Object peer_ )  :  int
SetACLResponse.deserialize ( InputArchive a_, String tag )  :  void
SetACLResponse.equals ( Object peer_ )  :  boolean
SetACLResponse.getStat ( )  :  Stat
SetACLResponse.hashCode ( )  :  int
SetACLResponse.readFields ( DataInput in )  :  void
SetACLResponse.serialize ( OutputArchive a_, String tag )  :  void
SetACLResponse.SetACLResponse ( )
SetACLResponse.SetACLResponse ( Stat stat )
SetACLResponse.setStat ( Stat m_ )  :  void
SetACLResponse.signature ( ) [static]  :  String
SetACLResponse.toString ( )  :  String
SetACLResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SetACLTxn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
SetACLTxn.compareTo ( Object peer_ )  :  int
SetACLTxn.deserialize ( InputArchive a_, String tag )  :  void
SetACLTxn.equals ( Object peer_ )  :  boolean
SetACLTxn.getAcl ( )  :  List<ACL>
SetACLTxn.getPath ( )  :  String
SetACLTxn.getVersion ( )  :  int
SetACLTxn.hashCode ( )  :  int
SetACLTxn.readFields ( DataInput in )  :  void
SetACLTxn.serialize ( OutputArchive a_, String tag )  :  void
SetACLTxn.setAcl ( List<ACL> m_ )  :  void
SetACLTxn.SetACLTxn ( )
SetACLTxn.SetACLTxn ( String path, List<ACL> acl, int version )
SetACLTxn.setPath ( String m_ )  :  void
SetACLTxn.setVersion ( int m_ )  :  void
SetACLTxn.signature ( ) [static]  :  String
SetACLTxn.toString ( )  :  String
SetACLTxn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SetDataRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
SetDataRequest.compareTo ( Object peer_ )  :  int
SetDataRequest.deserialize ( InputArchive a_, String tag )  :  void
SetDataRequest.equals ( Object peer_ )  :  boolean
SetDataRequest.getData ( )  :  byte[ ]
SetDataRequest.getPath ( )  :  String
SetDataRequest.getVersion ( )  :  int
SetDataRequest.hashCode ( )  :  int
SetDataRequest.readFields ( DataInput in )  :  void
SetDataRequest.serialize ( OutputArchive a_, String tag )  :  void
SetDataRequest.setData ( byte[ ] m_ )  :  void
SetDataRequest.SetDataRequest ( )
SetDataRequest.SetDataRequest ( String path, byte[ ] data, int version )
SetDataRequest.setPath ( String m_ )  :  void
SetDataRequest.setVersion ( int m_ )  :  void
SetDataRequest.signature ( ) [static]  :  String
SetDataRequest.toString ( )  :  String
SetDataRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SetDataResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
SetDataResponse.compareTo ( Object peer_ )  :  int
SetDataResponse.deserialize ( InputArchive a_, String tag )  :  void
SetDataResponse.equals ( Object peer_ )  :  boolean
SetDataResponse.getStat ( )  :  Stat
SetDataResponse.hashCode ( )  :  int
SetDataResponse.readFields ( DataInput in )  :  void
SetDataResponse.serialize ( OutputArchive a_, String tag )  :  void
SetDataResponse.SetDataResponse ( )
SetDataResponse.SetDataResponse ( Stat stat )
SetDataResponse.setStat ( Stat m_ )  :  void
SetDataResponse.signature ( ) [static]  :  String
SetDataResponse.toString ( )  :  String
SetDataResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SetDataTxn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
SetDataTxn.compareTo ( Object peer_ )  :  int
SetDataTxn.deserialize ( InputArchive a_, String tag )  :  void
SetDataTxn.equals ( Object peer_ )  :  boolean
SetDataTxn.getData ( )  :  byte[ ]
SetDataTxn.getPath ( )  :  String
SetDataTxn.getVersion ( )  :  int
SetDataTxn.hashCode ( )  :  int
SetDataTxn.readFields ( DataInput in )  :  void
SetDataTxn.serialize ( OutputArchive a_, String tag )  :  void
SetDataTxn.setData ( byte[ ] m_ )  :  void
SetDataTxn.SetDataTxn ( )
SetDataTxn.SetDataTxn ( String path, byte[ ] data, int version )
SetDataTxn.setPath ( String m_ )  :  void
SetDataTxn.setVersion ( int m_ )  :  void
SetDataTxn.signature ( ) [static]  :  String
SetDataTxn.toString ( )  :  String
SetDataTxn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SetMaxChildrenRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
SetMaxChildrenRequest.compareTo ( Object peer_ )  :  int
SetMaxChildrenRequest.deserialize ( InputArchive a_, String tag )  :  void
SetMaxChildrenRequest.equals ( Object peer_ )  :  boolean
SetMaxChildrenRequest.getMax ( )  :  int
SetMaxChildrenRequest.getPath ( )  :  String
SetMaxChildrenRequest.hashCode ( )  :  int
SetMaxChildrenRequest.readFields ( DataInput in )  :  void
SetMaxChildrenRequest.serialize ( OutputArchive a_, String tag )  :  void
SetMaxChildrenRequest.setMax ( int m_ )  :  void
SetMaxChildrenRequest.SetMaxChildrenRequest ( )
SetMaxChildrenRequest.SetMaxChildrenRequest ( String path, int max )
SetMaxChildrenRequest.setPath ( String m_ )  :  void
SetMaxChildrenRequest.signature ( ) [static]  :  String
SetMaxChildrenRequest.toString ( )  :  String
SetMaxChildrenRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SetMaxChildrenTxn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
SetMaxChildrenTxn.compareTo ( Object peer_ )  :  int
SetMaxChildrenTxn.deserialize ( InputArchive a_, String tag )  :  void
SetMaxChildrenTxn.equals ( Object peer_ )  :  boolean
SetMaxChildrenTxn.getMax ( )  :  int
SetMaxChildrenTxn.getPath ( )  :  String
SetMaxChildrenTxn.hashCode ( )  :  int
SetMaxChildrenTxn.readFields ( DataInput in )  :  void
SetMaxChildrenTxn.serialize ( OutputArchive a_, String tag )  :  void
SetMaxChildrenTxn.setMax ( int m_ )  :  void
SetMaxChildrenTxn.SetMaxChildrenTxn ( )
SetMaxChildrenTxn.SetMaxChildrenTxn ( String path, int max )
SetMaxChildrenTxn.setPath ( String m_ )  :  void
SetMaxChildrenTxn.signature ( ) [static]  :  String
SetMaxChildrenTxn.toString ( )  :  String
SetMaxChildrenTxn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SetSASLRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
SetSASLRequest.compareTo ( Object peer_ )  :  int
SetSASLRequest.deserialize ( InputArchive a_, String tag )  :  void
SetSASLRequest.equals ( Object peer_ )  :  boolean
SetSASLRequest.getToken ( )  :  byte[ ]
SetSASLRequest.hashCode ( )  :  int
SetSASLRequest.readFields ( DataInput in )  :  void
SetSASLRequest.serialize ( OutputArchive a_, String tag )  :  void
SetSASLRequest.SetSASLRequest ( )
SetSASLRequest.SetSASLRequest ( byte[ ] token )
SetSASLRequest.setToken ( byte[ ] m_ )  :  void
SetSASLRequest.signature ( ) [static]  :  String
SetSASLRequest.toString ( )  :  String
SetSASLRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SetSASLResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
SetSASLResponse.compareTo ( Object peer_ )  :  int
SetSASLResponse.deserialize ( InputArchive a_, String tag )  :  void
SetSASLResponse.equals ( Object peer_ )  :  boolean
SetSASLResponse.getToken ( )  :  byte[ ]
SetSASLResponse.hashCode ( )  :  int
SetSASLResponse.readFields ( DataInput in )  :  void
SetSASLResponse.serialize ( OutputArchive a_, String tag )  :  void
SetSASLResponse.SetSASLResponse ( )
SetSASLResponse.SetSASLResponse ( byte[ ] token )
SetSASLResponse.setToken ( byte[ ] m_ )  :  void
SetSASLResponse.signature ( ) [static]  :  String
SetSASLResponse.toString ( )  :  String
SetSASLResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SetWatches.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
SetWatches.compareTo ( Object peer_ )  :  int
SetWatches.deserialize ( InputArchive a_, String tag )  :  void
SetWatches.equals ( Object peer_ )  :  boolean
SetWatches.getChildWatches ( )  :  List<String>
SetWatches.getDataWatches ( )  :  List<String>
SetWatches.getExistWatches ( )  :  List<String>
SetWatches.getRelativeZxid ( )  :  long
SetWatches.hashCode ( )  :  int
SetWatches.readFields ( DataInput in )  :  void
SetWatches.serialize ( OutputArchive a_, String tag )  :  void
SetWatches.setChildWatches ( List<String> m_ )  :  void
SetWatches.setDataWatches ( List<String> m_ )  :  void
SetWatches.setExistWatches ( List<String> m_ )  :  void
SetWatches.setRelativeZxid ( long m_ )  :  void
SetWatches.SetWatches ( )
SetWatches.SetWatches ( long relativeZxid, List<String> dataWatches, List<String> existWatches, List<String> childWatches )
SetWatches.signature ( ) [static]  :  String
SetWatches.toString ( )  :  String
SetWatches.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SetWatches2.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
SetWatches2.compareTo ( Object peer_ )  :  int
SetWatches2.deserialize ( InputArchive a_, String tag )  :  void
SetWatches2.equals ( Object peer_ )  :  boolean
SetWatches2.getChildWatches ( )  :  List<String>
SetWatches2.getDataWatches ( )  :  List<String>
SetWatches2.getExistWatches ( )  :  List<String>
SetWatches2.getPersistentRecursiveWatches ( )  :  List<String>
SetWatches2.getPersistentWatches ( )  :  List<String>
SetWatches2.getRelativeZxid ( )  :  long
SetWatches2.hashCode ( )  :  int
SetWatches2.readFields ( DataInput in )  :  void
SetWatches2.serialize ( OutputArchive a_, String tag )  :  void
SetWatches2.setChildWatches ( List<String> m_ )  :  void
SetWatches2.setDataWatches ( List<String> m_ )  :  void
SetWatches2.setExistWatches ( List<String> m_ )  :  void
SetWatches2.setPersistentRecursiveWatches ( List<String> m_ )  :  void
SetWatches2.setPersistentWatches ( List<String> m_ )  :  void
SetWatches2.setRelativeZxid ( long m_ )  :  void
SetWatches2.SetWatches2 ( )
SetWatches2.SetWatches2 ( long relativeZxid, List<String> dataWatches, List<String> existWatches, List<String> childWatches, List<String> persistentWatches, List<String> persistentRecursiveWatches )
SetWatches2.signature ( ) [static]  :  String
SetWatches2.toString ( )  :  String
SetWatches2.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SingleColumnValueExcludeFilter.class
package org.apache.hadoop.hbase.filter
SingleColumnValueExcludeFilter.equals ( Object obj )  :  boolean
SingleColumnValueExcludeFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SingleColumnValueFilter.class
package org.apache.hadoop.hbase.filter
SingleColumnValueFilter.equals ( Object obj )  :  boolean
SingleColumnValueFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SkipFilter.class
package org.apache.hadoop.hbase.filter
SkipFilter.equals ( Object obj )  :  boolean
SkipFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SnapshotDescription.class
package org.apache.hadoop.hbase.client
SnapshotDescription.getMaxFileSize ( )  :  long
SnapshotDescription.getTtl ( )  :  long
SnapshotDescription.SnapshotDescription ( String name, TableName table, SnapshotType type, String owner, long creationTime, int version, Map<String,Object> snapshotProps )
SnapshotDescription.SnapshotDescription ( String snapshotName, TableName tableName, SnapshotType type, Map<String,Object> snapshotProps )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SnapshotFormatter.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.server
SnapshotFormatter.main ( String[ ] args ) [static]  :  void
SnapshotFormatter.run ( String snapshotFileName, boolean dumpData, boolean dumpJson )  :  void
SnapshotFormatter.SnapshotFormatter ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SnapshotTTLExpiredException.class
package org.apache.hadoop.hbase.snapshot
SnapshotTTLExpiredException.SnapshotTTLExpiredException ( SnapshotDescription snapshotDescription )
SnapshotTTLExpiredException.SnapshotTTLExpiredException ( String message )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SpaceQuotaSnapshotView.class
package org.apache.hadoop.hbase.quotas
SpaceQuotaSnapshotView.getLimit ( ) [abstract]  :  long
SpaceQuotaSnapshotView.getQuotaStatus ( ) [abstract]  :  SpaceQuotaSnapshotView.SpaceQuotaStatusView
SpaceQuotaSnapshotView.getUsage ( ) [abstract]  :  long

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SpaceQuotaStatusView.class
package org.apache.hadoop.hbase.quotas
SpaceQuotaSnapshotView.SpaceQuotaStatusView.getPolicy ( ) [abstract]  :  Optional<SpaceViolationPolicy>
SpaceQuotaSnapshotView.SpaceQuotaStatusView.isInViolation ( ) [abstract]  :  boolean

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Stat.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.data
Stat.compareTo ( Object peer_ )  :  int
Stat.deserialize ( InputArchive a_, String tag )  :  void
Stat.equals ( Object peer_ )  :  boolean
Stat.getAversion ( )  :  int
Stat.getCtime ( )  :  long
Stat.getCversion ( )  :  int
Stat.getCzxid ( )  :  long
Stat.getDataLength ( )  :  int
Stat.getEphemeralOwner ( )  :  long
Stat.getMtime ( )  :  long
Stat.getMzxid ( )  :  long
Stat.getNumChildren ( )  :  int
Stat.getPzxid ( )  :  long
Stat.getVersion ( )  :  int
Stat.hashCode ( )  :  int
Stat.readFields ( DataInput in )  :  void
Stat.serialize ( OutputArchive a_, String tag )  :  void
Stat.setAversion ( int m_ )  :  void
Stat.setCtime ( long m_ )  :  void
Stat.setCversion ( int m_ )  :  void
Stat.setCzxid ( long m_ )  :  void
Stat.setDataLength ( int m_ )  :  void
Stat.setEphemeralOwner ( long m_ )  :  void
Stat.setMtime ( long m_ )  :  void
Stat.setMzxid ( long m_ )  :  void
Stat.setNumChildren ( int m_ )  :  void
Stat.setPzxid ( long m_ )  :  void
Stat.setVersion ( int m_ )  :  void
Stat.signature ( ) [static]  :  String
Stat.Stat ( )
Stat.Stat ( long czxid, long mzxid, long ctime, long mtime, int version, int cversion, int aversion, long ephemeralOwner, int dataLength, int numChildren, long pzxid )
Stat.toString ( )  :  String
Stat.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, StatCallback.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
AsyncCallback.StatCallback.processResult ( int p1, String p2, Object p3, Stat p4 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, States.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
ZooKeeper.States.isAlive ( )  :  boolean
ZooKeeper.States.isConnected ( )  :  boolean
ZooKeeper.States.valueOf ( String name ) [static]  :  ZooKeeper.States
ZooKeeper.States.values ( ) [static]  :  ZooKeeper.States[ ]

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, StaticHostProvider.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.client
StaticHostProvider.getServerAtCurrentIndex ( )  :  InetSocketAddress
StaticHostProvider.getServerAtIndex ( int i )  :  InetSocketAddress
StaticHostProvider.next ( long spinDelay )  :  InetSocketAddress
StaticHostProvider.onConnected ( )  :  void
StaticHostProvider.size ( )  :  int
StaticHostProvider.StaticHostProvider ( Collection<InetSocketAddress> serverAddresses )
StaticHostProvider.StaticHostProvider ( Collection<InetSocketAddress> serverAddresses, long randomnessSeed )
StaticHostProvider.StaticHostProvider ( Collection<InetSocketAddress> serverAddresses, StaticHostProvider.Resolver resolver )
StaticHostProvider.updateServerList ( Collection<InetSocketAddress> serverAddresses, InetSocketAddress currentHost )  :  boolean

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, StatPersisted.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.data
StatPersisted.compareTo ( Object peer_ )  :  int
StatPersisted.deserialize ( InputArchive a_, String tag )  :  void
StatPersisted.equals ( Object peer_ )  :  boolean
StatPersisted.getAversion ( )  :  int
StatPersisted.getCtime ( )  :  long
StatPersisted.getCversion ( )  :  int
StatPersisted.getCzxid ( )  :  long
StatPersisted.getEphemeralOwner ( )  :  long
StatPersisted.getMtime ( )  :  long
StatPersisted.getMzxid ( )  :  long
StatPersisted.getPzxid ( )  :  long
StatPersisted.getVersion ( )  :  int
StatPersisted.hashCode ( )  :  int
StatPersisted.readFields ( DataInput in )  :  void
StatPersisted.serialize ( OutputArchive a_, String tag )  :  void
StatPersisted.setAversion ( int m_ )  :  void
StatPersisted.setCtime ( long m_ )  :  void
StatPersisted.setCversion ( int m_ )  :  void
StatPersisted.setCzxid ( long m_ )  :  void
StatPersisted.setEphemeralOwner ( long m_ )  :  void
StatPersisted.setMtime ( long m_ )  :  void
StatPersisted.setMzxid ( long m_ )  :  void
StatPersisted.setPzxid ( long m_ )  :  void
StatPersisted.setVersion ( int m_ )  :  void
StatPersisted.signature ( ) [static]  :  String
StatPersisted.StatPersisted ( )
StatPersisted.StatPersisted ( long czxid, long mzxid, long ctime, long mtime, int version, int cversion, int aversion, long ephemeralOwner, long pzxid )
StatPersisted.toString ( )  :  String
StatPersisted.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, StringCallback.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
AsyncCallback.StringCallback.processResult ( int p1, String p2, Object p3, String p4 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SyncReplicationState.class
package org.apache.hadoop.hbase.replication
SyncReplicationState.parseFrom ( byte[ ] bytes ) [static]  :  SyncReplicationState
SyncReplicationState.parseStateAndNewStateFrom ( byte[ ] bytes ) [static]  :  Pair<SyncReplicationState,SyncReplicationState>
SyncReplicationState.toByteArray ( SyncReplicationState state ) [static]  :  byte[ ]
SyncReplicationState.toByteArray ( SyncReplicationState state, SyncReplicationState newState ) [static]  :  byte[ ]
SyncReplicationState.value ( )  :  int
SyncReplicationState.valueOf ( int value ) [static]  :  SyncReplicationState
SyncReplicationState.valueOf ( String name ) [static]  :  SyncReplicationState
SyncReplicationState.values ( ) [static]  :  SyncReplicationState[ ]

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SyncRequest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
SyncRequest.compareTo ( Object peer_ )  :  int
SyncRequest.deserialize ( InputArchive a_, String tag )  :  void
SyncRequest.equals ( Object peer_ )  :  boolean
SyncRequest.getPath ( )  :  String
SyncRequest.hashCode ( )  :  int
SyncRequest.readFields ( DataInput in )  :  void
SyncRequest.serialize ( OutputArchive a_, String tag )  :  void
SyncRequest.setPath ( String m_ )  :  void
SyncRequest.signature ( ) [static]  :  String
SyncRequest.SyncRequest ( )
SyncRequest.SyncRequest ( String path )
SyncRequest.toString ( )  :  String
SyncRequest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SyncResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
SyncResponse.compareTo ( Object peer_ )  :  int
SyncResponse.deserialize ( InputArchive a_, String tag )  :  void
SyncResponse.equals ( Object peer_ )  :  boolean
SyncResponse.getPath ( )  :  String
SyncResponse.hashCode ( )  :  int
SyncResponse.readFields ( DataInput in )  :  void
SyncResponse.serialize ( OutputArchive a_, String tag )  :  void
SyncResponse.setPath ( String m_ )  :  void
SyncResponse.signature ( ) [static]  :  String
SyncResponse.SyncResponse ( )
SyncResponse.SyncResponse ( String path )
SyncResponse.toString ( )  :  String
SyncResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, SystemErrorException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.SystemErrorException.KeeperException.SystemErrorException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Table.class
package org.apache.hadoop.hbase.client
Table.batchCoprocessorService ( Descriptors.MethodDescriptor methodDescriptor, Message request, byte[ ] startKey, byte[ ] endKey, R responsePrototype )  :  Map<byte[ ],R> *DEPRECATED*
Table.batchCoprocessorService ( Descriptors.MethodDescriptor methodDescriptor, Message request, byte[ ] startKey, byte[ ] endKey, R responsePrototype, Batch.Callback<R> callback )  :  void *DEPRECATED*
Table.checkAndMutate ( byte[ ] row, Filter filter )  :  Table.CheckAndMutateWithFilterBuilder *DEPRECATED*
Table.checkAndMutate ( CheckAndMutate checkAndMutate )  :  CheckAndMutateResult
Table.checkAndMutate ( List<CheckAndMutate> checkAndMutates )  :  List<CheckAndMutateResult>
Table.getRegionLocator ( ) [abstract]  :  RegionLocator
Table.getRequestAttributes ( )  :  Map<String,byte[ ]>
Table.mutateRow ( RowMutations rm )  :  Result

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, TableBuilder.class
package org.apache.hadoop.hbase.client
TableBuilder.setRequestAttribute ( String p1, byte[ ] p2 ) [abstract]  :  TableBuilder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, TableDescriptor.class
package org.apache.hadoop.hbase.client
TableDescriptor.getErasureCodingPolicy ( )  :  String
TableDescriptor.getNormalizerTargetRegionCount ( ) [abstract]  :  int
TableDescriptor.getNormalizerTargetRegionSize ( ) [abstract]  :  long
TableDescriptor.getRegionServerGroup ( ) [abstract]  :  Optional<String>
TableDescriptor.hasGlobalReplicationScope ( )  :  boolean
TableDescriptor.isMergeEnabled ( ) [abstract]  :  boolean
TableDescriptor.isSplitEnabled ( ) [abstract]  :  boolean
TableDescriptor.toStringCustomizedValues ( ) [abstract]  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, TableDescriptorBuilder.class
package org.apache.hadoop.hbase.client
TableDescriptorBuilder.getUnit ( String key ) [static]  :  PrettyPrinter.Unit
TableDescriptorBuilder.getValue ( String key )  :  String
TableDescriptorBuilder.hasCoprocessor ( String classNameToMatch )  :  boolean
TableDescriptorBuilder.removeValue ( BiPredicate<Bytes,Bytes> predicate )  :  TableDescriptorBuilder
TableDescriptorBuilder.removeValue ( String key )  :  TableDescriptorBuilder
TableDescriptorBuilder.setErasureCodingPolicy ( String policy )  :  TableDescriptorBuilder
TableDescriptorBuilder.setMaxFileSize ( String maxFileSize )  :  TableDescriptorBuilder
TableDescriptorBuilder.setMemStoreFlushSize ( String memStoreFlushSize )  :  TableDescriptorBuilder
TableDescriptorBuilder.setMergeEnabled ( boolean isEnable )  :  TableDescriptorBuilder
TableDescriptorBuilder.setNormalizerTargetRegionCount ( int regionCount )  :  TableDescriptorBuilder
TableDescriptorBuilder.setNormalizerTargetRegionSize ( long regionSize )  :  TableDescriptorBuilder
TableDescriptorBuilder.setRegionServerGroup ( String group )  :  TableDescriptorBuilder
TableDescriptorBuilder.setSplitEnabled ( boolean isEnable )  :  TableDescriptorBuilder

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, TableDescriptorUtils.class
package org.apache.hadoop.hbase.client
TableDescriptorUtils.computeDelta ( TableDescriptor oldTD, TableDescriptor newTD ) [static]  :  TableDescriptorUtils.TableDescriptorDelta

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, TableName.class
package org.apache.hadoop.hbase
TableName.valueOf ( byte[ ] fullName, int offset, int length ) [static]  :  TableName
TableName.valueOf ( ByteBuffer fullname ) [static]  :  TableName

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, TablePermission.class
package org.apache.hadoop.hbase.security.access
TablePermission.equalsExceptActions ( Object obj )  :  boolean
TablePermission.implies ( TableName table, byte[ ] family, Permission.Action action )  :  boolean
TablePermission.rawExpression ( )  :  String

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, TimeRange.class
package org.apache.hadoop.hbase.io
TimeRange.between ( long minStamp, long maxStamp ) [static]  :  TimeRange
TimeRange.from ( long minStamp ) [static]  :  TimeRange
TimeRange.until ( long maxStamp ) [static]  :  TimeRange

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, TimestampsFilter.class
package org.apache.hadoop.hbase.filter
TimestampsFilter.equals ( Object obj )  :  boolean
TimestampsFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Transaction.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
Transaction.check ( String path, int version )  :  Transaction
Transaction.commit ( )  :  List<OpResult>
Transaction.commit ( AsyncCallback.MultiCallback cb, Object ctx )  :  void
Transaction.create ( String path, byte[ ] data, List<ACL> acl, CreateMode createMode )  :  Transaction
Transaction.delete ( String path, int version )  :  Transaction
Transaction.setData ( String path, byte[ ] data, int version )  :  Transaction
Transaction.Transaction ( ZooKeeper zk )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Txn.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
Txn.compareTo ( Object peer_ )  :  int
Txn.deserialize ( InputArchive a_, String tag )  :  void
Txn.equals ( Object peer_ )  :  boolean
Txn.getData ( )  :  byte[ ]
Txn.getType ( )  :  int
Txn.hashCode ( )  :  int
Txn.readFields ( DataInput in )  :  void
Txn.serialize ( OutputArchive a_, String tag )  :  void
Txn.setData ( byte[ ] m_ )  :  void
Txn.setType ( int m_ )  :  void
Txn.signature ( ) [static]  :  String
Txn.toString ( )  :  String
Txn.Txn ( )
Txn.Txn ( int type, byte[ ] data )
Txn.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, TxnDigest.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
TxnDigest.compareTo ( Object peer_ )  :  int
TxnDigest.deserialize ( InputArchive a_, String tag )  :  void
TxnDigest.equals ( Object peer_ )  :  boolean
TxnDigest.getTreeDigest ( )  :  long
TxnDigest.getVersion ( )  :  int
TxnDigest.hashCode ( )  :  int
TxnDigest.readFields ( DataInput in )  :  void
TxnDigest.serialize ( OutputArchive a_, String tag )  :  void
TxnDigest.setTreeDigest ( long m_ )  :  void
TxnDigest.setVersion ( int m_ )  :  void
TxnDigest.signature ( ) [static]  :  String
TxnDigest.toString ( )  :  String
TxnDigest.TxnDigest ( )
TxnDigest.TxnDigest ( int version, long treeDigest )
TxnDigest.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, TxnHeader.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.txn
TxnHeader.compareTo ( Object peer_ )  :  int
TxnHeader.deserialize ( InputArchive a_, String tag )  :  void
TxnHeader.equals ( Object peer_ )  :  boolean
TxnHeader.getClientId ( )  :  long
TxnHeader.getCxid ( )  :  int
TxnHeader.getTime ( )  :  long
TxnHeader.getType ( )  :  int
TxnHeader.getZxid ( )  :  long
TxnHeader.hashCode ( )  :  int
TxnHeader.readFields ( DataInput in )  :  void
TxnHeader.serialize ( OutputArchive a_, String tag )  :  void
TxnHeader.setClientId ( long m_ )  :  void
TxnHeader.setCxid ( int m_ )  :  void
TxnHeader.setTime ( long m_ )  :  void
TxnHeader.setType ( int m_ )  :  void
TxnHeader.setZxid ( long m_ )  :  void
TxnHeader.signature ( ) [static]  :  String
TxnHeader.toString ( )  :  String
TxnHeader.TxnHeader ( )
TxnHeader.TxnHeader ( long clientId, int cxid, long zxid, long time, int type )
TxnHeader.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, UnimplementedException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.UnimplementedException.KeeperException.UnimplementedException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, UnknownRegionException.class
package org.apache.hadoop.hbase
UnknownRegionException.UnknownRegionException ( String message, Throwable cause )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, UnknownSessionException.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
KeeperException.UnknownSessionException.KeeperException.UnknownSessionException ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, User.class
package org.apache.hadoop.hbase.security
User.isLoginFromKeytab ( )  :  boolean
User.login ( String keytabLocation, String pricipalName ) [static]  :  void
User.shouldLoginFromKeytab ( Configuration conf ) [static]  :  boolean

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, UserMetrics.class
package org.apache.hadoop.hbase
UserMetrics.getClientMetrics ( ) [abstract]  :  Map<String,UserMetrics.ClientMetrics>
UserMetrics.getFilteredReadRequests ( ) [abstract]  :  long
UserMetrics.getNameAsString ( )  :  String
UserMetrics.getReadRequestCount ( ) [abstract]  :  long
UserMetrics.getRequestCount ( )  :  long
UserMetrics.getUserName ( ) [abstract]  :  byte[ ]
UserMetrics.getWriteRequestCount ( ) [abstract]  :  long

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, UserPermission.class
package org.apache.hadoop.hbase.security.access
UserPermission.equalsExceptActions ( Object obj )  :  boolean
UserPermission.getAccessScope ( )  :  Permission.Scope
UserPermission.getPermission ( )  :  Permission
UserPermission.getUser ( )  :  String
UserPermission.UserPermission ( String user, Permission permission )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ValueFilter.class
package org.apache.hadoop.hbase.filter
ValueFilter.equals ( Object obj )  :  boolean
ValueFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, VersionInfo.class
package org.apache.hadoop.hbase.util
VersionInfo.getMajorVersion ( String version ) [static]  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, VisibilityClient.class
package org.apache.hadoop.hbase.security.visibility
VisibilityClient.addLabel ( Connection connection, String label ) [static]  :  VisibilityLabelsProtos.VisibilityLabelsResponse
VisibilityClient.addLabels ( Connection connection, String[ ] labels ) [static]  :  VisibilityLabelsProtos.VisibilityLabelsResponse
VisibilityClient.clearAuths ( Connection connection, String[ ] auths, String user ) [static]  :  VisibilityLabelsProtos.VisibilityLabelsResponse
VisibilityClient.getAuths ( Connection connection, String user ) [static]  :  VisibilityLabelsProtos.GetAuthsResponse
VisibilityClient.listLabels ( Connection connection, String regex ) [static]  :  VisibilityLabelsProtos.ListLabelsResponse
VisibilityClient.setAuths ( Connection connection, String[ ] auths, String user ) [static]  :  VisibilityLabelsProtos.VisibilityLabelsResponse

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, VoidCallback.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
AsyncCallback.VoidCallback.processResult ( int p1, String p2, Object p3 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, WatchedEvent.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
WatchedEvent.getPath ( )  :  String
WatchedEvent.getState ( )  :  Watcher.Event.KeeperState
WatchedEvent.getType ( )  :  Watcher.Event.EventType
WatchedEvent.getWrapper ( )  :  WatcherEvent
WatchedEvent.toString ( )  :  String
WatchedEvent.WatchedEvent ( Watcher.Event.EventType eventType, Watcher.Event.KeeperState keeperState, String path )
WatchedEvent.WatchedEvent ( WatcherEvent eventMessage )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, Watcher.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
Watcher.process ( WatchedEvent p1 ) [abstract]  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, WatcherEvent.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
WatcherEvent.compareTo ( Object peer_ )  :  int
WatcherEvent.deserialize ( InputArchive a_, String tag )  :  void
WatcherEvent.equals ( Object peer_ )  :  boolean
WatcherEvent.getPath ( )  :  String
WatcherEvent.getState ( )  :  int
WatcherEvent.getType ( )  :  int
WatcherEvent.hashCode ( )  :  int
WatcherEvent.readFields ( DataInput in )  :  void
WatcherEvent.serialize ( OutputArchive a_, String tag )  :  void
WatcherEvent.setPath ( String m_ )  :  void
WatcherEvent.setState ( int m_ )  :  void
WatcherEvent.setType ( int m_ )  :  void
WatcherEvent.signature ( ) [static]  :  String
WatcherEvent.toString ( )  :  String
WatcherEvent.WatcherEvent ( )
WatcherEvent.WatcherEvent ( int type, int state, String path )
WatcherEvent.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, WatcherType.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
Watcher.WatcherType.fromInt ( int intValue ) [static]  :  Watcher.WatcherType
Watcher.WatcherType.getIntValue ( )  :  int
Watcher.WatcherType.valueOf ( String name ) [static]  :  Watcher.WatcherType
Watcher.WatcherType.values ( ) [static]  :  Watcher.WatcherType[ ]

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, WhileMatchFilter.class
package org.apache.hadoop.hbase.filter
WhileMatchFilter.equals ( Object obj )  :  boolean
WhileMatchFilter.hashCode ( )  :  int

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, WhoAmIResponse.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.proto
WhoAmIResponse.compareTo ( Object peer_ )  :  int
WhoAmIResponse.deserialize ( InputArchive a_, String tag )  :  void
WhoAmIResponse.equals ( Object peer_ )  :  boolean
WhoAmIResponse.getClientInfo ( )  :  List<ClientInfo>
WhoAmIResponse.hashCode ( )  :  int
WhoAmIResponse.readFields ( DataInput in )  :  void
WhoAmIResponse.serialize ( OutputArchive a_, String tag )  :  void
WhoAmIResponse.setClientInfo ( List<ClientInfo> m_ )  :  void
WhoAmIResponse.signature ( ) [static]  :  String
WhoAmIResponse.toString ( )  :  String
WhoAmIResponse.WhoAmIResponse ( )
WhoAmIResponse.WhoAmIResponse ( List<ClientInfo> clientInfo )
WhoAmIResponse.write ( DataOutput out )  :  void

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ZKClientConfig.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.client
ZKClientConfig.getLong ( String key, long defaultValue )  :  long
ZKClientConfig.handleBackwardCompatibility ( )  :  void
ZKClientConfig.isSaslClientEnabled ( )  :  boolean
ZKClientConfig.ZKClientConfig ( )
ZKClientConfig.ZKClientConfig ( File configFile )
ZKClientConfig.ZKClientConfig ( String configPath )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ZooDefs.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
ZooDefs.ZooDefs ( )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ZooKeeper.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper
ZooKeeper.addAuthInfo ( String scheme, byte[ ] auth )  :  void
ZooKeeper.addWatch ( String basePath, AddWatchMode mode )  :  void
ZooKeeper.addWatch ( String basePath, AddWatchMode mode, AsyncCallback.VoidCallback cb, Object ctx )  :  void
ZooKeeper.addWatch ( String basePath, Watcher watcher, AddWatchMode mode )  :  void
ZooKeeper.addWatch ( String basePath, Watcher watcher, AddWatchMode mode, AsyncCallback.VoidCallback cb, Object ctx )  :  void
ZooKeeper.close ( )  :  void
ZooKeeper.close ( int waitForShutdownTimeoutMs )  :  boolean
ZooKeeper.create ( String path, byte[ ] data, List<ACL> acl, CreateMode createMode )  :  String
ZooKeeper.create ( String path, byte[ ] data, List<ACL> acl, CreateMode createMode, AsyncCallback.Create2Callback cb, Object ctx )  :  void
ZooKeeper.create ( String path, byte[ ] data, List<ACL> acl, CreateMode createMode, AsyncCallback.Create2Callback cb, Object ctx, long ttl )  :  void
ZooKeeper.create ( String path, byte[ ] data, List<ACL> acl, CreateMode createMode, AsyncCallback.StringCallback cb, Object ctx )  :  void
ZooKeeper.create ( String path, byte[ ] data, List<ACL> acl, CreateMode createMode, Stat stat )  :  String
ZooKeeper.create ( String path, byte[ ] data, List<ACL> acl, CreateMode createMode, Stat stat, long ttl )  :  String
ZooKeeper.delete ( String path, int version )  :  void
ZooKeeper.delete ( String path, int version, AsyncCallback.VoidCallback cb, Object ctx )  :  void
ZooKeeper.exists ( String path, boolean watch )  :  Stat
ZooKeeper.exists ( String path, boolean watch, AsyncCallback.StatCallback cb, Object ctx )  :  void
ZooKeeper.exists ( String path, Watcher watcher )  :  Stat
ZooKeeper.exists ( String path, Watcher watcher, AsyncCallback.StatCallback cb, Object ctx )  :  void
ZooKeeper.getACL ( String path, Stat stat )  :  List<ACL>
ZooKeeper.getACL ( String path, Stat stat, AsyncCallback.ACLCallback cb, Object ctx )  :  void
ZooKeeper.getAllChildrenNumber ( String path )  :  int
ZooKeeper.getAllChildrenNumber ( String path, AsyncCallback.AllChildrenNumberCallback cb, Object ctx )  :  void
ZooKeeper.getChildren ( String path, boolean watch )  :  List<String>
ZooKeeper.getChildren ( String path, boolean watch, AsyncCallback.Children2Callback cb, Object ctx )  :  void
ZooKeeper.getChildren ( String path, boolean watch, AsyncCallback.ChildrenCallback cb, Object ctx )  :  void
ZooKeeper.getChildren ( String path, boolean watch, Stat stat )  :  List<String>
ZooKeeper.getChildren ( String path, Watcher watcher )  :  List<String>
ZooKeeper.getChildren ( String path, Watcher watcher, AsyncCallback.Children2Callback cb, Object ctx )  :  void
ZooKeeper.getChildren ( String path, Watcher watcher, AsyncCallback.ChildrenCallback cb, Object ctx )  :  void
ZooKeeper.getChildren ( String path, Watcher watcher, Stat stat )  :  List<String>
ZooKeeper.getChildWatches ( )  :  List<String>
ZooKeeper.getClientConfig ( )  :  ZKClientConfig
ZooKeeper.getConfig ( boolean watch, AsyncCallback.DataCallback cb, Object ctx )  :  void
ZooKeeper.getConfig ( boolean watch, Stat stat )  :  byte[ ]
ZooKeeper.getConfig ( Watcher watcher, AsyncCallback.DataCallback cb, Object ctx )  :  void
ZooKeeper.getConfig ( Watcher watcher, Stat stat )  :  byte[ ]
ZooKeeper.getData ( String path, boolean watch, AsyncCallback.DataCallback cb, Object ctx )  :  void
ZooKeeper.getData ( String path, boolean watch, Stat stat )  :  byte[ ]
ZooKeeper.getData ( String path, Watcher watcher, AsyncCallback.DataCallback cb, Object ctx )  :  void
ZooKeeper.getData ( String path, Watcher watcher, Stat stat )  :  byte[ ]
ZooKeeper.getDataWatches ( )  :  List<String>
ZooKeeper.getEphemerals ( )  :  List<String>
ZooKeeper.getEphemerals ( AsyncCallback.EphemeralsCallback cb, Object ctx )  :  void
ZooKeeper.getEphemerals ( String prefixPath )  :  List<String>
ZooKeeper.getEphemerals ( String prefixPath, AsyncCallback.EphemeralsCallback cb, Object ctx )  :  void
ZooKeeper.getExistWatches ( )  :  List<String>
ZooKeeper.getPersistentRecursiveWatches ( )  :  List<String>
ZooKeeper.getPersistentWatches ( )  :  List<String>
ZooKeeper.getSaslClient ( )  :  ZooKeeperSaslClient
ZooKeeper.getSessionId ( )  :  long
ZooKeeper.getSessionPasswd ( )  :  byte[ ]
ZooKeeper.getSessionTimeout ( )  :  int
ZooKeeper.getState ( )  :  ZooKeeper.States
ZooKeeper.getTestable ( )  :  Testable
ZooKeeper.multi ( Iterable<Op> ops )  :  List<OpResult>
ZooKeeper.multi ( Iterable<Op> ops, AsyncCallback.MultiCallback cb, Object ctx )  :  void
ZooKeeper.multiInternal ( MultiOperationRecord request )  :  List<OpResult>
ZooKeeper.multiInternal ( MultiOperationRecord request, AsyncCallback.MultiCallback cb, Object ctx )  :  void
ZooKeeper.register ( Watcher watcher )  :  void
ZooKeeper.removeAllWatches ( String path, Watcher.WatcherType watcherType, boolean local )  :  void
ZooKeeper.removeAllWatches ( String path, Watcher.WatcherType watcherType, boolean local, AsyncCallback.VoidCallback cb, Object ctx )  :  void
ZooKeeper.removeWatches ( String path, Watcher watcher, Watcher.WatcherType watcherType, boolean local )  :  void
ZooKeeper.removeWatches ( String path, Watcher watcher, Watcher.WatcherType watcherType, boolean local, AsyncCallback.VoidCallback cb, Object ctx )  :  void
ZooKeeper.setACL ( String path, List<ACL> acl, int aclVersion )  :  Stat
ZooKeeper.setACL ( String path, List<ACL> acl, int version, AsyncCallback.StatCallback cb, Object ctx )  :  void
ZooKeeper.setData ( String path, byte[ ] data, int version )  :  Stat
ZooKeeper.setData ( String path, byte[ ] data, int version, AsyncCallback.StatCallback cb, Object ctx )  :  void
ZooKeeper.sync ( String path, AsyncCallback.VoidCallback cb, Object ctx )  :  void
ZooKeeper.testableLocalSocketAddress ( )  :  SocketAddress
ZooKeeper.testableRemoteSocketAddress ( )  :  SocketAddress
ZooKeeper.testableWaitForShutdown ( int wait )  :  boolean
ZooKeeper.toString ( )  :  String
ZooKeeper.transaction ( )  :  Transaction
ZooKeeper.updateServerList ( String connectString )  :  void
ZooKeeper.whoAmI ( )  :  List<ClientInfo>
ZooKeeper.ZooKeeper ( String connectString, int sessionTimeout, Watcher watcher )
ZooKeeper.ZooKeeper ( String connectString, int sessionTimeout, Watcher watcher, boolean canBeReadOnly )
ZooKeeper.ZooKeeper ( String connectString, int sessionTimeout, Watcher watcher, boolean canBeReadOnly, HostProvider aHostProvider )
ZooKeeper.ZooKeeper ( String connectString, int sessionTimeout, Watcher watcher, boolean canBeReadOnly, HostProvider hostProvider, ZKClientConfig clientConfig )
ZooKeeper.ZooKeeper ( String connectString, int sessionTimeout, Watcher watcher, boolean canBeReadOnly, ZKClientConfig conf )
ZooKeeper.ZooKeeper ( String connectString, int sessionTimeout, Watcher watcher, long sessionId, byte[ ] sessionPasswd )
ZooKeeper.ZooKeeper ( String connectString, int sessionTimeout, Watcher watcher, long sessionId, byte[ ] sessionPasswd, boolean canBeReadOnly )
ZooKeeper.ZooKeeper ( String connectString, int sessionTimeout, Watcher watcher, long sessionId, byte[ ] sessionPasswd, boolean canBeReadOnly, HostProvider aHostProvider )
ZooKeeper.ZooKeeper ( String connectString, int sessionTimeout, Watcher watcher, long sessionId, byte[ ] sessionPasswd, boolean canBeReadOnly, HostProvider hostProvider, ZKClientConfig clientConfig )
ZooKeeper.ZooKeeper ( String connectString, int sessionTimeout, Watcher watcher, ZKClientConfig conf )

hbase-shaded-client-byo-hadoop-3.0.0-beta-1.jar, ZooKeeperAdmin.class
package org.apache.hadoop.hbase.shaded.org.apache.zookeeper.admin
ZooKeeperAdmin.reconfigure ( List<String> joiningServers, List<String> leavingServers, List<String> newMembers, long fromConfig, AsyncCallback.DataCallback cb, Object ctx )  :  void
ZooKeeperAdmin.reconfigure ( List<String> joiningServers, List<String> leavingServers