API compatibility report for the hbase library between rel/1.6.0 and 1.7.0RC0 versions


Binary
Compatibility
Source
Compatibility

Test Info


Library Namehbase
Version #1rel/1.6.0
Version #21.7.0RC0
SubjectBinary Compatibility

Test Results


Total Java Modules18
Total Methods / Classes6613 / 564
Compatibility 95.5%

Problem Summary


SeverityCount
Added Methods-127
Removed MethodsHigh79
Problems with
Data Types
High5
Medium3
Low3
Problems with
Methods
High0
Medium0
Low2
Other Changes
in Data Types
-14

Added Methods  127 


hbase-client-1.7.0.jar, Admin.class
package org.apache.hadoop.hbase.client
Admin.clearSlowLogResponses ( Set<ServerName> p1 ) [abstract]  :  List<Boolean>
Admin.getLogEntries ( Set<ServerName> p1, String p2, ServerType p3, int p4, Map<String,Object> p5 ) [abstract]  :  List<LogEntry>

hbase-client-1.7.0.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-client-1.7.0.jar, Builder.class
package org.apache.hadoop.hbase.client
BalancerDecision.Builder.BalancerDecision.Builder ( )
BalancerDecision.Builder.build ( )  :  BalancerDecision
BalancerDecision.Builder.setComputedSteps ( long computedSteps )  :  BalancerDecision.Builder
BalancerDecision.Builder.setComputedTotalCost ( double computedTotalCost )  :  BalancerDecision.Builder
BalancerDecision.Builder.setFinalFunctionCosts ( String finalFunctionCosts )  :  BalancerDecision.Builder
BalancerDecision.Builder.setInitialFunctionCosts ( String initialFunctionCosts )  :  BalancerDecision.Builder
BalancerDecision.Builder.setInitTotalCost ( double initTotalCost )  :  BalancerDecision.Builder
BalancerDecision.Builder.setRegionPlans ( List<String> regionPlans )  :  BalancerDecision.Builder

hbase-client-1.7.0.jar, Connection.class
package org.apache.hadoop.hbase.client
Connection.getClusterId ( ) [abstract]  :  String

hbase-client-1.7.0.jar, HColumnDescriptor.class
package org.apache.hadoop.hbase
HColumnDescriptor.setVersionsWithTimeToLive ( int retentionInterval, int versionAfterInterval )  :  HColumnDescriptor

hbase-client-1.7.0.jar, HConnection.class
package org.apache.hadoop.hbase.client
HConnection.getTableState ( TableName p1 ) [abstract]  :  TableState

hbase-client-1.7.0.jar, HTableDescriptor.class
package org.apache.hadoop.hbase
HTableDescriptor.getNormalizerTargetRegionCount ( )  :  int
HTableDescriptor.getNormalizerTargetRegionSize ( )  :  long
HTableDescriptor.setNormalizerTargetRegionCount ( int regionCount )  :  HTableDescriptor
HTableDescriptor.setNormalizerTargetRegionSize ( long regionSize )  :  HTableDescriptor

hbase-client-1.7.0.jar, LogEntry.class
package org.apache.hadoop.hbase.client
LogEntry.LogEntry ( )
LogEntry.toJsonPrettyPrint ( ) [abstract]  :  String

hbase-client-1.7.0.jar, OnlineLogRecord.class
package org.apache.hadoop.hbase.client
OnlineLogRecord.equals ( Object o )  :  boolean
OnlineLogRecord.getCallDetails ( )  :  String
OnlineLogRecord.getClientAddress ( )  :  String
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.getResponseSize ( )  :  long
OnlineLogRecord.getServerClass ( )  :  String
OnlineLogRecord.getStartTime ( )  :  long
OnlineLogRecord.getUserName ( )  :  String
OnlineLogRecord.hashCode ( )  :  int
OnlineLogRecord.toJsonPrettyPrint ( )  :  String
OnlineLogRecord.toString ( )  :  String

hbase-client-1.7.0.jar, OnlineLogRecordBuilder.class
package org.apache.hadoop.hbase.client
OnlineLogRecord.OnlineLogRecordBuilder.build ( )  :  OnlineLogRecord
OnlineLogRecord.OnlineLogRecordBuilder.OnlineLogRecord.OnlineLogRecordBuilder ( )
OnlineLogRecord.OnlineLogRecordBuilder.setCallDetails ( String callDetails )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setClientAddress ( String clientAddress )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setMethodName ( String methodName )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setMultiGetsCount ( int multiGetsCount )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setMultiMutationsCount ( int multiMutationsCount )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setMultiServiceCalls ( int multiServiceCalls )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setParam ( String param )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setProcessingTime ( int processingTime )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setQueueTime ( int queueTime )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setRegionName ( String regionName )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setResponseSize ( long responseSize )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setServerClass ( String serverClass )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setStartTime ( long startTime )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setUserName ( String userName )  :  OnlineLogRecord.OnlineLogRecordBuilder

hbase-client-1.7.0.jar, ReplicationPeerConfig.class
package org.apache.hadoop.hbase.replication
ReplicationPeerConfig.addBasePeerConfigsIfNotPresent ( Configuration conf )  :  void

hbase-client-1.7.0.jar, ServerName.class
package org.apache.hadoop.hbase
ServerName.getHostnameLowerCase ( )  :  String

hbase-client-1.7.0.jar, ServerTooBusyException.class
package org.apache.hadoop.hbase.ipc
ServerTooBusyException.ServerTooBusyException ( Address address, long count )

hbase-client-1.7.0.jar, ServerType.class
package org.apache.hadoop.hbase.client
ServerType.valueOf ( String name ) [static]  :  ServerType
ServerType.values ( ) [static]  :  ServerType[ ]

hbase-client-1.7.0.jar, State.class
package org.apache.hadoop.hbase.client
TableState.State.convert ( )  :  HBaseProtos.TableState.State
TableState.State.convert ( HBaseProtos.TableState.State state ) [static]  :  TableState.State
TableState.State.valueOf ( String name ) [static]  :  TableState.State
TableState.State.values ( ) [static]  :  TableState.State[ ]

hbase-common-1.7.0.jar, Address.class
package org.apache.hadoop.hbase.net
Address.fromSocketAddress ( InetSocketAddress addr ) [static]  :  Address
Address.getHostName ( )  :  String
Address.toSocketAddress ( )  :  InetSocketAddress
Address.toSocketAddress ( Address[ ] addrs ) [static]  :  InetSocketAddress[ ]

hbase-common-1.7.0.jar, CellUtil.class
package org.apache.hadoop.hbase
CellUtil.matchingTags ( Cell left, Cell right ) [static]  :  boolean

hbase-it-1.7.0.jar, ChaosConstants.class
package org.apache.hadoop.hbase.chaos
ChaosConstants.ChaosConstants ( )

hbase-server-1.7.0.jar, BaseMasterAndRegionObserver.class
package org.apache.hadoop.hbase.coprocessor
BaseMasterAndRegionObserver.postRenameRSGroup ( ObserverContext<MasterCoprocessorEnvironment> ctx, String oldName, String newName )  :  void
BaseMasterAndRegionObserver.preRenameRSGroup ( ObserverContext<MasterCoprocessorEnvironment> ctx, String oldName, String newName )  :  void

hbase-server-1.7.0.jar, BaseMasterObserver.class
package org.apache.hadoop.hbase.coprocessor
BaseMasterObserver.postRenameRSGroup ( ObserverContext<MasterCoprocessorEnvironment> ctx, String oldName, String newName )  :  void
BaseMasterObserver.preRenameRSGroup ( ObserverContext<MasterCoprocessorEnvironment> ctx, String oldName, String newName )  :  void

hbase-server-1.7.0.jar, CompactionRequest.class
package org.apache.hadoop.hbase.regionserver.compactions
CompactionRequest.isAfterSplit ( )  :  boolean
CompactionRequest.setAfterSplit ( boolean afterSplit )  :  void

hbase-server-1.7.0.jar, HFileOutputFormat2.class
package org.apache.hadoop.hbase.mapreduce
HFileOutputFormat2.configureRemoteCluster ( Job job, Configuration clusterConf ) [static]  :  void

hbase-server-1.7.0.jar, HLogPrettyPrinter.class
package org.apache.hadoop.hbase.regionserver.wal
HLogPrettyPrinter.HLogPrettyPrinter ( boolean outputValues, boolean outputJSON, long sequence, String table, String region, String row, String rowPrefix, boolean persistentOutput, PrintStream out )

hbase-server-1.7.0.jar, HMaster.class
package org.apache.hadoop.hbase.master
HMaster.getActiveMaster ( )  :  ServerName
HMaster.getClusterId ( )  :  String
HMaster.getMetaRegionLocationCache ( )  :  MetaRegionLocationCache
HMaster.getNumLiveRegionServers ( )  :  int
HMaster.getTableStateManager ( )  :  TableStateManager
HMaster.isOnline ( )  :  boolean

hbase-server-1.7.0.jar, HRegionServer.class
package org.apache.hadoop.hbase.regionserver
HRegionServer.getNamedQueueRecorder ( )  :  NamedQueueRecorder
HRegionServer.setAbortRequested ( )  :  boolean

hbase-server-1.7.0.jar, MasterObserver.class
package org.apache.hadoop.hbase.coprocessor
MasterObserver.postRenameRSGroup ( ObserverContext<MasterCoprocessorEnvironment> p1, String p2, String p3 ) [abstract]  :  void
MasterObserver.preRenameRSGroup ( ObserverContext<MasterCoprocessorEnvironment> p1, String p2, String p3 ) [abstract]  :  void

hbase-server-1.7.0.jar, MetricsSource.class
package org.apache.hadoop.hbase.replication.regionserver
MetricsSource.decrSourceInitializing ( )  :  void
MetricsSource.getAgeOfLastShippedOp ( String walGroup )  :  long
MetricsSource.getOldestWalAge ( )  :  long
MetricsSource.getSourceInitializing ( )  :  int
MetricsSource.incrSourceInitializing ( )  :  void
MetricsSource.setOldestWalAge ( long age )  :  void
MetricsSource.updateTableLevelMetrics ( List<Pair<WAL.Entry,Long>> walEntries )  :  void

hbase-server-1.7.0.jar, ReplicationLogCleaner.class
package org.apache.hadoop.hbase.replication.master
ReplicationLogCleaner.init ( Configuration conf, ZooKeeperWatcher zk, ReplicationQueuesClient replicationQueuesClient )  :  void
ReplicationLogCleaner.init ( Map<String,Object> params )  :  void

hbase-server-1.7.0.jar, RpcServer.class
package org.apache.hadoop.hbase.ipc
RpcServer.refreshAuthManager ( Configuration conf, PolicyProvider pp )  :  void
RpcServer.setNamedQueueRecorder ( NamedQueueRecorder namedQueueRecorder )  :  void

hbase-server-1.7.0.jar, RpcServerInterface.class
package org.apache.hadoop.hbase.ipc
RpcServerInterface.refreshAuthManager ( Configuration p1, PolicyProvider p2 ) [abstract]  :  void
RpcServerInterface.setNamedQueueRecorder ( NamedQueueRecorder p1 ) [abstract]  :  void

hbase-server-1.7.0.jar, SimpleRegionNormalizer.class
package org.apache.hadoop.hbase.master.normalizer
SimpleRegionNormalizer.computePlansForTable ( TableName table )  :  List<NormalizationPlan>
SimpleRegionNormalizer.getConf ( )  :  Configuration
SimpleRegionNormalizer.getMergeMinRegionAge ( )  :  int
SimpleRegionNormalizer.getMergeMinRegionSizeMb ( )  :  int
SimpleRegionNormalizer.getMinRegionCount ( )  :  int
SimpleRegionNormalizer.isMergeEnabled ( )  :  boolean
SimpleRegionNormalizer.isSplitEnabled ( )  :  boolean
SimpleRegionNormalizer.setConf ( Configuration conf )  :  void

hbase-server-1.7.0.jar, Store.class
package org.apache.hadoop.hbase.regionserver
Store.createWriterInTmp ( long p1, Compression.Algorithm p2, boolean p3, boolean p4, boolean p5, boolean p6, long p7 ) [abstract]  :  StoreFile.Writer
Store.createWriterInTmp ( long p1, Compression.Algorithm p2, boolean p3, boolean p4, boolean p5, boolean p6, TimeRangeTracker p7, long p8 ) [abstract]  :  StoreFile.Writer

hbase-server-1.7.0.jar, TableSplit.class
package org.apache.hadoop.hbase.mapreduce
TableSplit.getScanAsString ( )  :  String

hbase-server-1.7.0.jar, WALCellCodec.class
package org.apache.hadoop.hbase.regionserver.wal
WALCellCodec.getNoneCompressor ( ) [static]  :  WALCellCodec.ByteStringCompressor
WALCellCodec.getNoneUncompressor ( ) [static]  :  WALCellCodec.ByteStringUncompressor

hbase-server-1.7.0.jar, WALEntryFilterRetryableException.class
package org.apache.hadoop.hbase.replication.regionserver
WALEntryFilterRetryableException.WALEntryFilterRetryableException ( String m )
WALEntryFilterRetryableException.WALEntryFilterRetryableException ( String m, Throwable t )

hbase-server-1.7.0.jar, WALPrettyPrinter.class
package org.apache.hadoop.hbase.wal
WALPrettyPrinter.printCell ( PrintStream out, Map<String,Object> op, boolean outputValues, boolean outputOnlyRowKey ) [static]  :  void
WALPrettyPrinter.setOutputOnlyRowKey ( )  :  void
WALPrettyPrinter.setRowPrefixFilter ( String rowPrefix )  :  void
WALPrettyPrinter.toStringMap ( Cell cell, boolean printRowKeyOnly, String rowPrefix, String row, boolean outputValues ) [static]  :  Map<String,Object>
WALPrettyPrinter.WALPrettyPrinter ( boolean outputValues, boolean outputJSON, long sequence, Set<String> tableSet, String region, String row, String rowPrefix, boolean outputOnlyRowKey, boolean persistentOutput, PrintStream out )

to the top

Removed Methods  79 


hbase-rest-1.6.0.jar, RemoteAdmin.class
package org.apache.hadoop.hbase.rest.client
RemoteAdmin.createTable ( HTableDescriptor desc )  :  void
RemoteAdmin.deleteTable ( byte[ ] tableName )  :  void
RemoteAdmin.deleteTable ( String tableName )  :  void
RemoteAdmin.getClusterStatus ( )  :  StorageClusterStatusModel
RemoteAdmin.getClusterVersion ( )  :  StorageClusterVersionModel
RemoteAdmin.getRestVersion ( )  :  VersionModel
RemoteAdmin.getTableList ( )  :  TableListModel
RemoteAdmin.isTableAvailable ( byte[ ] tableName )  :  boolean
RemoteAdmin.isTableAvailable ( String tableName )  :  boolean
RemoteAdmin.RemoteAdmin ( Client client, Configuration conf )
RemoteAdmin.RemoteAdmin ( Client client, Configuration conf, String accessToken )

hbase-rest-1.6.0.jar, RemoteHTable.class
package org.apache.hadoop.hbase.rest.client
RemoteHTable.append ( Append append )  :  Result
RemoteHTable.batch ( List<?> actions )  :  Object[ ]
RemoteHTable.batch ( List<?> actions, Object[ ] results )  :  void
RemoteHTable.batchCallback ( List<?> actions, Batch.Callback<R> callback )  :  Object[ ]
RemoteHTable.batchCallback ( List<?> actions, Object[ ] results, Batch.Callback<R> callback )  :  void
RemoteHTable.batchCoprocessorService ( Descriptors.MethodDescriptor method, Message request, byte[ ] startKey, byte[ ] endKey, R responsePrototype )  :  Map<byte[ ],R>
RemoteHTable.batchCoprocessorService ( Descriptors.MethodDescriptor method, Message request, byte[ ] startKey, byte[ ] endKey, R responsePrototype, Batch.Callback<R> callback )  :  void
RemoteHTable.buildModelFromPut ( Put put )  :  CellSetModel
RemoteHTable.buildMultiRowSpec ( byte[ ][ ] rows, int maxVersions )  :  String
RemoteHTable.buildResultFromModel ( CellSetModel model )  :  Result[ ]
RemoteHTable.buildRowSpec ( byte[ ] row, Map familyMap, long startTime, long endTime, int maxVersions )  :  String
RemoteHTable.checkAndDelete ( byte[ ] row, byte[ ] family, byte[ ] qualifier, byte[ ] value, Delete delete )  :  boolean
RemoteHTable.checkAndDelete ( byte[ ] row, byte[ ] family, byte[ ] qualifier, CompareFilter.CompareOp compareOp, byte[ ] value, Delete delete )  :  boolean
RemoteHTable.checkAndMutate ( byte[ ] row, byte[ ] family, byte[ ] qualifier, CompareFilter.CompareOp compareOp, byte[ ] value, RowMutations rm )  :  boolean
RemoteHTable.checkAndPut ( byte[ ] row, byte[ ] family, byte[ ] qualifier, byte[ ] value, Put put )  :  boolean
RemoteHTable.checkAndPut ( byte[ ] row, byte[ ] family, byte[ ] qualifier, CompareFilter.CompareOp compareOp, byte[ ] value, Put put )  :  boolean
RemoteHTable.close ( )  :  void
RemoteHTable.coprocessorService ( byte[ ] row )  :  CoprocessorRpcChannel
RemoteHTable.coprocessorService ( Class<T> service, byte[ ] startKey, byte[ ] endKey, Batch.Call<T,R> callable )  :  Map<byte[ ],R>
RemoteHTable.coprocessorService ( Class<T> service, byte[ ] startKey, byte[ ] endKey, Batch.Call<T,R> callable, Batch.Callback<R> callback )  :  void
RemoteHTable.delete ( Delete delete )  :  void
RemoteHTable.delete ( List<Delete> deletes )  :  void
RemoteHTable.exists ( Get get )  :  boolean
RemoteHTable.exists ( List<Get> gets )  :  Boolean[ ]
RemoteHTable.existsAll ( List<Get> gets )  :  boolean[ ]
RemoteHTable.flushCommits ( )  :  void
RemoteHTable.get ( Get get )  :  Result
RemoteHTable.get ( List<Get> gets )  :  Result[ ]
RemoteHTable.getConfiguration ( )  :  Configuration
RemoteHTable.getName ( )  :  TableName
RemoteHTable.getOperationTimeout ( )  :  int
RemoteHTable.getReadRpcTimeout ( )  :  int
RemoteHTable.getRowOrBefore ( byte[ ] row, byte[ ] family )  :  Result
RemoteHTable.getRpcTimeout ( )  :  int *DEPRECATED*
RemoteHTable.getScanner ( byte[ ] family )  :  ResultScanner
RemoteHTable.getScanner ( byte[ ] family, byte[ ] qualifier )  :  ResultScanner
RemoteHTable.getScanner ( Scan scan )  :  ResultScanner
RemoteHTable.getTableDescriptor ( )  :  HTableDescriptor
RemoteHTable.getTableName ( )  :  byte[ ]
RemoteHTable.getWriteBufferSize ( )  :  long
RemoteHTable.getWriteRpcTimeout ( )  :  int
RemoteHTable.increment ( Increment increment )  :  Result
RemoteHTable.incrementColumnValue ( byte[ ] row, byte[ ] family, byte[ ] qualifier, long amount )  :  long
RemoteHTable.incrementColumnValue ( byte[ ] row, byte[ ] family, byte[ ] qualifier, long amount, Durability durability )  :  long
RemoteHTable.isAutoFlush ( )  :  boolean
RemoteHTable.mutateRow ( RowMutations rm )  :  void
RemoteHTable.put ( List<Put> puts )  :  void
RemoteHTable.put ( Put put )  :  void
RemoteHTable.RemoteHTable ( Client client, Configuration conf, byte[ ] name )
RemoteHTable.RemoteHTable ( Client client, Configuration conf, String name )
RemoteHTable.RemoteHTable ( Client client, String name )
RemoteHTable.setOperationTimeout ( int operationTimeout )  :  void
RemoteHTable.setReadRpcTimeout ( int readRpcTimeout )  :  void
RemoteHTable.setRpcTimeout ( int rpcTimeout )  :  void *DEPRECATED*
RemoteHTable.setWriteBufferSize ( long writeBufferSize )  :  void
RemoteHTable.setWriteRpcTimeout ( int writeRpcTimeout )  :  void

hbase-server-1.6.0.jar, HLogPrettyPrinter.class
package org.apache.hadoop.hbase.regionserver.wal
HLogPrettyPrinter.HLogPrettyPrinter ( boolean outputValues, boolean outputJSON, long sequence, String table, String region, String row, boolean persistentOutput, PrintStream out )

hbase-server-1.6.0.jar, MetricsSource.class
package org.apache.hadoop.hbase.replication.regionserver
MetricsSource.getAgeofLastShippedOp ( String walGroup )  :  long

hbase-server-1.6.0.jar, ReplicationLogCleaner.class
package org.apache.hadoop.hbase.replication.master
ReplicationLogCleaner.setConf ( Configuration conf, ZooKeeperWatcher zk )  :  void
ReplicationLogCleaner.setConf ( Configuration conf, ZooKeeperWatcher zk, ReplicationQueuesClient replicationQueuesClient )  :  void

hbase-server-1.6.0.jar, WALPrettyPrinter.class
package org.apache.hadoop.hbase.wal
WALPrettyPrinter.WALPrettyPrinter ( boolean outputValues, boolean outputJSON, long sequence, String table, String region, String row, boolean persistentOutput, PrintStream out )

hbase-server-1.6.0.jar, ZkCoordinatedStateManager.class
package org.apache.hadoop.hbase.coordination
ZkCoordinatedStateManager.getTableStateManager ( )  :  TableStateManager

hbase-thrift-1.6.0.jar, ThriftServer.class
package org.apache.hadoop.hbase.thrift
ThriftServer.main ( String[ ] args ) [static]  :  void
ThriftServer.stop ( )  :  void
ThriftServer.ThriftServer ( Configuration conf )

hbase-thrift-1.6.0.jar, ThriftServer.class
package org.apache.hadoop.hbase.thrift2
ThriftServer.main ( String[ ] args ) [static]  :  void
ThriftServer.registerFilters ( Configuration conf ) [static]  :  void
ThriftServer.ThriftServer ( )

to the top

Problems with Data Types, High Severity  5 


hbase-rest-1.6.0.jar
package org.apache.hadoop.hbase.rest.client
[+] class RemoteAdmin  1 
[+] class RemoteHTable  1 

hbase-server-1.6.0.jar
package org.apache.hadoop.hbase.regionserver
[+] class HRegionServer  1 

hbase-thrift-1.6.0.jar
package org.apache.hadoop.hbase.thrift
[+] class ThriftServer  1 

hbase-thrift-1.6.0.jar
package org.apache.hadoop.hbase.thrift2
[+] class ThriftServer  1 

to the top

Problems with Data Types, Medium Severity  3 


hbase-client-1.6.0.jar
package org.apache.hadoop.hbase.client
[+] interface HConnection  1 

hbase-server-1.6.0.jar
package org.apache.hadoop.hbase.regionserver
[+] interface Store  2 

to the top

Problems with Data Types, Low Severity  3 


hbase-server-1.6.0.jar
package org.apache.hadoop.hbase.master
[+] class HMaster  2 

hbase-server-1.6.0.jar
package org.apache.hadoop.hbase.replication.master
[+] class ReplicationLogCleaner  1 

to the top

Problems with Methods, Low Severity  2 


hbase-server-1.6.0.jar, HRegionServer.class
package org.apache.hadoop.hbase.regionserver
[+] HRegionServer.getRegionBlockLocations ( String encodedRegionName )  :  InetSocketAddress[ ]  1 

hbase-server-1.6.0.jar, RpcServer.class
package org.apache.hadoop.hbase.ipc
[+] RpcServer.refreshAuthManager ( PolicyProvider pp )  :  void  1 

to the top

Other Changes in Data Types  14 


hbase-client-1.6.0.jar
package org.apache.hadoop.hbase
[+] class HTableDescriptor  2 

hbase-client-1.6.0.jar
package org.apache.hadoop.hbase.client
[+] interface Admin  2 
[+] interface Connection  1 

hbase-client-1.6.0.jar
package org.apache.hadoop.hbase.filter
[+] class ParseConstants  1 

hbase-client-1.6.0.jar
package org.apache.hadoop.hbase.replication
[+] class ReplicationPeerConfig  1 

hbase-server-1.6.0.jar
package org.apache.hadoop.hbase.coprocessor
[+] interface MasterObserver  2 

hbase-server-1.6.0.jar
package org.apache.hadoop.hbase.ipc
[+] interface RpcServerInterface  2 

hbase-server-1.6.0.jar
package org.apache.hadoop.hbase.mapreduce
[+] class HFileOutputFormat2  3 

to the top

Java Archives  18 


hbase-annotations-1.6.0.jar
hbase-client-1.6.0.jar
hbase-client-project-1.6.0.jar
hbase-common-1.6.0.jar
hbase-examples-1.6.0.jar
hbase-external-blockcache-1.6.0.jar
hbase-hadoop-compat-1.6.0.jar
hbase-hadoop2-compat-1.6.0.jar
hbase-hbtop-1.6.0.jar
hbase-metrics-api-1.6.0.jar
hbase-prefix-tree-1.6.0.jar
hbase-procedure-1.6.0.jar
hbase-protocol-1.6.0.jar
hbase-rest-1.6.0.jar
hbase-rsgroup-1.6.0.jar
hbase-server-1.6.0.jar
hbase-shaded-client-project-1.6.0.jar
hbase-thrift-1.6.0.jar

to the top



Test Info


Library Namehbase
Version #1rel/1.6.0
Version #21.7.0RC0
SubjectSource Compatibility

Test Results


Total Java Modules18
Total Methods / Classes6613 / 564
Compatibility 88.7%

Problem Summary


SeverityCount
Added Methods-127
Removed MethodsHigh79
Problems with
Data Types
High15
Medium0
Low0
Problems with
Methods
High0
Medium1
Low0
Other Changes
in Data Types
-7

Added Methods  127 


hbase-client-1.7.0.jar, Admin.class
package org.apache.hadoop.hbase.client
Admin.clearSlowLogResponses ( Set<ServerName> p1 ) [abstract]  :  List<Boolean>
Admin.getLogEntries ( Set<ServerName> p1, String p2, ServerType p3, int p4, Map<String,Object> p5 ) [abstract]  :  List<LogEntry>

hbase-client-1.7.0.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-client-1.7.0.jar, Builder.class
package org.apache.hadoop.hbase.client
BalancerDecision.Builder.BalancerDecision.Builder ( )
BalancerDecision.Builder.build ( )  :  BalancerDecision
BalancerDecision.Builder.setComputedSteps ( long computedSteps )  :  BalancerDecision.Builder
BalancerDecision.Builder.setComputedTotalCost ( double computedTotalCost )  :  BalancerDecision.Builder
BalancerDecision.Builder.setFinalFunctionCosts ( String finalFunctionCosts )  :  BalancerDecision.Builder
BalancerDecision.Builder.setInitialFunctionCosts ( String initialFunctionCosts )  :  BalancerDecision.Builder
BalancerDecision.Builder.setInitTotalCost ( double initTotalCost )  :  BalancerDecision.Builder
BalancerDecision.Builder.setRegionPlans ( List<String> regionPlans )  :  BalancerDecision.Builder

hbase-client-1.7.0.jar, Connection.class
package org.apache.hadoop.hbase.client
Connection.getClusterId ( ) [abstract]  :  String

hbase-client-1.7.0.jar, HColumnDescriptor.class
package org.apache.hadoop.hbase
HColumnDescriptor.setVersionsWithTimeToLive ( int retentionInterval, int versionAfterInterval )  :  HColumnDescriptor

hbase-client-1.7.0.jar, HConnection.class
package org.apache.hadoop.hbase.client
HConnection.getTableState ( TableName p1 ) [abstract]  :  TableState

hbase-client-1.7.0.jar, HTableDescriptor.class
package org.apache.hadoop.hbase
HTableDescriptor.getNormalizerTargetRegionCount ( )  :  int
HTableDescriptor.getNormalizerTargetRegionSize ( )  :  long
HTableDescriptor.setNormalizerTargetRegionCount ( int regionCount )  :  HTableDescriptor
HTableDescriptor.setNormalizerTargetRegionSize ( long regionSize )  :  HTableDescriptor

hbase-client-1.7.0.jar, LogEntry.class
package org.apache.hadoop.hbase.client
LogEntry.LogEntry ( )
LogEntry.toJsonPrettyPrint ( ) [abstract]  :  String

hbase-client-1.7.0.jar, OnlineLogRecord.class
package org.apache.hadoop.hbase.client
OnlineLogRecord.equals ( Object o )  :  boolean
OnlineLogRecord.getCallDetails ( )  :  String
OnlineLogRecord.getClientAddress ( )  :  String
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.getResponseSize ( )  :  long
OnlineLogRecord.getServerClass ( )  :  String
OnlineLogRecord.getStartTime ( )  :  long
OnlineLogRecord.getUserName ( )  :  String
OnlineLogRecord.hashCode ( )  :  int
OnlineLogRecord.toJsonPrettyPrint ( )  :  String
OnlineLogRecord.toString ( )  :  String

hbase-client-1.7.0.jar, OnlineLogRecordBuilder.class
package org.apache.hadoop.hbase.client
OnlineLogRecord.OnlineLogRecordBuilder.build ( )  :  OnlineLogRecord
OnlineLogRecord.OnlineLogRecordBuilder.OnlineLogRecord.OnlineLogRecordBuilder ( )
OnlineLogRecord.OnlineLogRecordBuilder.setCallDetails ( String callDetails )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setClientAddress ( String clientAddress )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setMethodName ( String methodName )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setMultiGetsCount ( int multiGetsCount )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setMultiMutationsCount ( int multiMutationsCount )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setMultiServiceCalls ( int multiServiceCalls )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setParam ( String param )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setProcessingTime ( int processingTime )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setQueueTime ( int queueTime )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setRegionName ( String regionName )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setResponseSize ( long responseSize )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setServerClass ( String serverClass )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setStartTime ( long startTime )  :  OnlineLogRecord.OnlineLogRecordBuilder
OnlineLogRecord.OnlineLogRecordBuilder.setUserName ( String userName )  :  OnlineLogRecord.OnlineLogRecordBuilder

hbase-client-1.7.0.jar, ReplicationPeerConfig.class
package org.apache.hadoop.hbase.replication
ReplicationPeerConfig.addBasePeerConfigsIfNotPresent ( Configuration conf )  :  void

hbase-client-1.7.0.jar, ServerName.class
package org.apache.hadoop.hbase
ServerName.getHostnameLowerCase ( )  :  String

hbase-client-1.7.0.jar, ServerTooBusyException.class
package org.apache.hadoop.hbase.ipc
ServerTooBusyException.ServerTooBusyException ( Address address, long count )

hbase-client-1.7.0.jar, ServerType.class
package org.apache.hadoop.hbase.client
ServerType.valueOf ( String name ) [static]  :  ServerType
ServerType.values ( ) [static]  :  ServerType[ ]

hbase-client-1.7.0.jar, State.class
package org.apache.hadoop.hbase.client
TableState.State.convert ( )  :  HBaseProtos.TableState.State
TableState.State.convert ( HBaseProtos.TableState.State state ) [static]  :  TableState.State
TableState.State.valueOf ( String name ) [static]  :  TableState.State
TableState.State.values ( ) [static]  :  TableState.State[ ]

hbase-common-1.7.0.jar, Address.class
package org.apache.hadoop.hbase.net
Address.fromSocketAddress ( InetSocketAddress addr ) [static]  :  Address
Address.getHostName ( )  :  String
Address.toSocketAddress ( )  :  InetSocketAddress
Address.toSocketAddress ( Address[ ] addrs ) [static]  :  InetSocketAddress[ ]

hbase-common-1.7.0.jar, CellUtil.class
package org.apache.hadoop.hbase
CellUtil.matchingTags ( Cell left, Cell right ) [static]  :  boolean

hbase-it-1.7.0.jar, ChaosConstants.class
package org.apache.hadoop.hbase.chaos
ChaosConstants.ChaosConstants ( )

hbase-server-1.7.0.jar, BaseMasterAndRegionObserver.class
package org.apache.hadoop.hbase.coprocessor
BaseMasterAndRegionObserver.postRenameRSGroup ( ObserverContext<MasterCoprocessorEnvironment> ctx, String oldName, String newName )  :  void
BaseMasterAndRegionObserver.preRenameRSGroup ( ObserverContext<MasterCoprocessorEnvironment> ctx, String oldName, String newName )  :  void

hbase-server-1.7.0.jar, BaseMasterObserver.class
package org.apache.hadoop.hbase.coprocessor
BaseMasterObserver.postRenameRSGroup ( ObserverContext<MasterCoprocessorEnvironment> ctx, String oldName, String newName )  :  void
BaseMasterObserver.preRenameRSGroup ( ObserverContext<MasterCoprocessorEnvironment> ctx, String oldName, String newName )  :  void

hbase-server-1.7.0.jar, CompactionRequest.class
package org.apache.hadoop.hbase.regionserver.compactions
CompactionRequest.isAfterSplit ( )  :  boolean
CompactionRequest.setAfterSplit ( boolean afterSplit )  :  void

hbase-server-1.7.0.jar, HFileOutputFormat2.class
package org.apache.hadoop.hbase.mapreduce
HFileOutputFormat2.configureRemoteCluster ( Job job, Configuration clusterConf ) [static]  :  void

hbase-server-1.7.0.jar, HLogPrettyPrinter.class
package org.apache.hadoop.hbase.regionserver.wal
HLogPrettyPrinter.HLogPrettyPrinter ( boolean outputValues, boolean outputJSON, long sequence, String table, String region, String row, String rowPrefix, boolean persistentOutput, PrintStream out )

hbase-server-1.7.0.jar, HMaster.class
package org.apache.hadoop.hbase.master
HMaster.getActiveMaster ( )  :  ServerName
HMaster.getClusterId ( )  :  String
HMaster.getMetaRegionLocationCache ( )  :  MetaRegionLocationCache
HMaster.getNumLiveRegionServers ( )  :  int
HMaster.getTableStateManager ( )  :  TableStateManager
HMaster.isOnline ( )  :  boolean

hbase-server-1.7.0.jar, HRegionServer.class
package org.apache.hadoop.hbase.regionserver
HRegionServer.getNamedQueueRecorder ( )  :  NamedQueueRecorder
HRegionServer.setAbortRequested ( )  :  boolean

hbase-server-1.7.0.jar, MasterObserver.class
package org.apache.hadoop.hbase.coprocessor
MasterObserver.postRenameRSGroup ( ObserverContext<MasterCoprocessorEnvironment> p1, String p2, String p3 ) [abstract]  :  void
MasterObserver.preRenameRSGroup ( ObserverContext<MasterCoprocessorEnvironment> p1, String p2, String p3 ) [abstract]  :  void

hbase-server-1.7.0.jar, MetricsSource.class
package org.apache.hadoop.hbase.replication.regionserver
MetricsSource.decrSourceInitializing ( )  :  void
MetricsSource.getAgeOfLastShippedOp ( String walGroup )  :  long
MetricsSource.getOldestWalAge ( )  :  long
MetricsSource.getSourceInitializing ( )  :  int
MetricsSource.incrSourceInitializing ( )  :  void
MetricsSource.setOldestWalAge ( long age )  :  void
MetricsSource.updateTableLevelMetrics ( List<Pair<WAL.Entry,Long>> walEntries )  :  void

hbase-server-1.7.0.jar, ReplicationLogCleaner.class
package org.apache.hadoop.hbase.replication.master
ReplicationLogCleaner.init ( Configuration conf, ZooKeeperWatcher zk, ReplicationQueuesClient replicationQueuesClient )  :  void
ReplicationLogCleaner.init ( Map<String,Object> params )  :  void

hbase-server-1.7.0.jar, RpcServer.class
package org.apache.hadoop.hbase.ipc
RpcServer.refreshAuthManager ( Configuration conf, PolicyProvider pp )  :  void
RpcServer.setNamedQueueRecorder ( NamedQueueRecorder namedQueueRecorder )  :  void

hbase-server-1.7.0.jar, RpcServerInterface.class
package org.apache.hadoop.hbase.ipc
RpcServerInterface.refreshAuthManager ( Configuration p1, PolicyProvider p2 ) [abstract]  :  void
RpcServerInterface.setNamedQueueRecorder ( NamedQueueRecorder p1 ) [abstract]  :  void

hbase-server-1.7.0.jar, SimpleRegionNormalizer.class
package org.apache.hadoop.hbase.master.normalizer
SimpleRegionNormalizer.computePlansForTable ( TableName table )  :  List<NormalizationPlan>
SimpleRegionNormalizer.getConf ( )  :  Configuration
SimpleRegionNormalizer.getMergeMinRegionAge ( )  :  int
SimpleRegionNormalizer.getMergeMinRegionSizeMb ( )  :  int
SimpleRegionNormalizer.getMinRegionCount ( )  :  int
SimpleRegionNormalizer.isMergeEnabled ( )  :  boolean
SimpleRegionNormalizer.isSplitEnabled ( )  :  boolean
SimpleRegionNormalizer.setConf ( Configuration conf )  :  void

hbase-server-1.7.0.jar, Store.class
package org.apache.hadoop.hbase.regionserver
Store.createWriterInTmp ( long p1, Compression.Algorithm p2, boolean p3, boolean p4, boolean p5, boolean p6, long p7 ) [abstract]  :  StoreFile.Writer
Store.createWriterInTmp ( long p1, Compression.Algorithm p2, boolean p3, boolean p4, boolean p5, boolean p6, TimeRangeTracker p7, long p8 ) [abstract]  :  StoreFile.Writer

hbase-server-1.7.0.jar, TableSplit.class
package org.apache.hadoop.hbase.mapreduce
TableSplit.getScanAsString ( )  :  String

hbase-server-1.7.0.jar, WALCellCodec.class
package org.apache.hadoop.hbase.regionserver.wal
WALCellCodec.getNoneCompressor ( ) [static]  :  WALCellCodec.ByteStringCompressor
WALCellCodec.getNoneUncompressor ( ) [static]  :  WALCellCodec.ByteStringUncompressor

hbase-server-1.7.0.jar, WALEntryFilterRetryableException.class
package org.apache.hadoop.hbase.replication.regionserver
WALEntryFilterRetryableException.WALEntryFilterRetryableException ( String m )
WALEntryFilterRetryableException.WALEntryFilterRetryableException ( String m, Throwable t )

hbase-server-1.7.0.jar, WALPrettyPrinter.class
package org.apache.hadoop.hbase.wal
WALPrettyPrinter.printCell ( PrintStream out, Map<String,Object> op, boolean outputValues, boolean outputOnlyRowKey ) [static]  :  void
WALPrettyPrinter.setOutputOnlyRowKey ( )  :  void
WALPrettyPrinter.setRowPrefixFilter ( String rowPrefix )  :  void
WALPrettyPrinter.toStringMap ( Cell cell, boolean printRowKeyOnly, String rowPrefix, String row, boolean outputValues ) [static]  :  Map<String,Object>
WALPrettyPrinter.WALPrettyPrinter ( boolean outputValues, boolean outputJSON, long sequence, Set<String> tableSet, String region, String row, String rowPrefix, boolean outputOnlyRowKey, boolean persistentOutput, PrintStream out )

to the top

Removed Methods  79 


hbase-rest-1.6.0.jar, RemoteAdmin.class
package org.apache.hadoop.hbase.rest.client
RemoteAdmin.createTable ( HTableDescriptor desc )  :  void
RemoteAdmin.deleteTable ( byte[ ] tableName )  :  void
RemoteAdmin.deleteTable ( String tableName )  :  void
RemoteAdmin.getClusterStatus ( )  :  StorageClusterStatusModel
RemoteAdmin.getClusterVersion ( )  :  StorageClusterVersionModel
RemoteAdmin.getRestVersion ( )  :  VersionModel
RemoteAdmin.getTableList ( )  :  TableListModel
RemoteAdmin.isTableAvailable ( byte[ ] tableName )  :  boolean
RemoteAdmin.isTableAvailable ( String tableName )  :  boolean
RemoteAdmin.RemoteAdmin ( Client client, Configuration conf )
RemoteAdmin.RemoteAdmin ( Client client, Configuration conf, String accessToken )

hbase-rest-1.6.0.jar, RemoteHTable.class
package org.apache.hadoop.hbase.rest.client
RemoteHTable.append ( Append append )  :  Result
RemoteHTable.batch ( List<?> actions )  :  Object[ ]
RemoteHTable.batch ( List<?> actions, Object[ ] results )  :  void
RemoteHTable.batchCallback ( List<?> actions, Batch.Callback<R> callback )  :  Object[ ]
RemoteHTable.batchCallback ( List<?> actions, Object[ ] results, Batch.Callback<R> callback )  :  void
RemoteHTable.batchCoprocessorService ( Descriptors.MethodDescriptor method, Message request, byte[ ] startKey, byte[ ] endKey, R responsePrototype )  :  Map<byte[ ],R>
RemoteHTable.batchCoprocessorService ( Descriptors.MethodDescriptor method, Message request, byte[ ] startKey, byte[ ] endKey, R responsePrototype, Batch.Callback<R> callback )  :  void
RemoteHTable.buildModelFromPut ( Put put )  :  CellSetModel
RemoteHTable.buildMultiRowSpec ( byte[ ][ ] rows, int maxVersions )  :  String
RemoteHTable.buildResultFromModel ( CellSetModel model )  :  Result[ ]
RemoteHTable.buildRowSpec ( byte[ ] row, Map familyMap, long startTime, long endTime, int maxVersions )  :  String
RemoteHTable.checkAndDelete ( byte[ ] row, byte[ ] family, byte[ ] qualifier, byte[ ] value, Delete delete )  :  boolean
RemoteHTable.checkAndDelete ( byte[ ] row, byte[ ] family, byte[ ] qualifier, CompareFilter.CompareOp compareOp, byte[ ] value, Delete delete )  :  boolean
RemoteHTable.checkAndMutate ( byte[ ] row, byte[ ] family, byte[ ] qualifier, CompareFilter.CompareOp compareOp, byte[ ] value, RowMutations rm )  :  boolean
RemoteHTable.checkAndPut ( byte[ ] row, byte[ ] family, byte[ ] qualifier, byte[ ] value, Put put )  :  boolean
RemoteHTable.checkAndPut ( byte[ ] row, byte[ ] family, byte[ ] qualifier, CompareFilter.CompareOp compareOp, byte[ ] value, Put put )  :  boolean
RemoteHTable.close ( )  :  void
RemoteHTable.coprocessorService ( byte[ ] row )  :  CoprocessorRpcChannel
RemoteHTable.coprocessorService ( Class<T> service, byte[ ] startKey, byte[ ] endKey, Batch.Call<T,R> callable )  :  Map<byte[ ],R>
RemoteHTable.coprocessorService ( Class<T> service, byte[ ] startKey, byte[ ] endKey, Batch.Call<T,R> callable, Batch.Callback<R> callback )  :  void
RemoteHTable.delete ( Delete delete )  :  void
RemoteHTable.delete ( List<Delete> deletes )  :  void
RemoteHTable.exists ( Get get )  :  boolean
RemoteHTable.exists ( List<Get> gets )  :  Boolean[ ]
RemoteHTable.existsAll ( List<Get> gets )  :  boolean[ ]
RemoteHTable.flushCommits ( )  :  void
RemoteHTable.get ( Get get )  :  Result
RemoteHTable.get ( List<Get> gets )  :  Result[ ]
RemoteHTable.getConfiguration ( )  :  Configuration
RemoteHTable.getName ( )  :  TableName
RemoteHTable.getOperationTimeout ( )  :  int
RemoteHTable.getReadRpcTimeout ( )  :  int
RemoteHTable.getRowOrBefore ( byte[ ] row, byte[ ] family )  :  Result
RemoteHTable.getRpcTimeout ( )  :  int *DEPRECATED*
RemoteHTable.getScanner ( byte[ ] family )  :  ResultScanner
RemoteHTable.getScanner ( byte[ ] family, byte[ ] qualifier )  :  ResultScanner
RemoteHTable.getScanner ( Scan scan )  :  ResultScanner
RemoteHTable.getTableDescriptor ( )  :  HTableDescriptor
RemoteHTable.getTableName ( )  :  byte[ ]
RemoteHTable.getWriteBufferSize ( )  :  long
RemoteHTable.getWriteRpcTimeout ( )  :  int
RemoteHTable.increment ( Increment increment )  :  Result
RemoteHTable.incrementColumnValue ( byte[ ] row, byte[ ] family, byte[ ] qualifier, long amount )  :  long
RemoteHTable.incrementColumnValue ( byte[ ] row, byte[ ] family, byte[ ] qualifier, long amount, Durability durability )  :  long
RemoteHTable.isAutoFlush ( )  :  boolean
RemoteHTable.mutateRow ( RowMutations rm )  :  void
RemoteHTable.put ( List<Put> puts )  :  void
RemoteHTable.put ( Put put )  :  void
RemoteHTable.RemoteHTable ( Client client, Configuration conf, byte[ ] name )
RemoteHTable.RemoteHTable ( Client client, Configuration conf, String name )
RemoteHTable.RemoteHTable ( Client client, String name )
RemoteHTable.setOperationTimeout ( int operationTimeout )  :  void
RemoteHTable.setReadRpcTimeout ( int readRpcTimeout )  :  void
RemoteHTable.setRpcTimeout ( int rpcTimeout )  :  void *DEPRECATED*
RemoteHTable.setWriteBufferSize ( long writeBufferSize )  :  void
RemoteHTable.setWriteRpcTimeout ( int writeRpcTimeout )  :  void

hbase-server-1.6.0.jar, HLogPrettyPrinter.class
package org.apache.hadoop.hbase.regionserver.wal
HLogPrettyPrinter.HLogPrettyPrinter ( boolean outputValues, boolean outputJSON, long sequence, String table, String region, String row, boolean persistentOutput, PrintStream out )

hbase-server-1.6.0.jar, MetricsSource.class
package org.apache.hadoop.hbase.replication.regionserver
MetricsSource.getAgeofLastShippedOp ( String walGroup )  :  long

hbase-server-1.6.0.jar, ReplicationLogCleaner.class
package org.apache.hadoop.hbase.replication.master
ReplicationLogCleaner.setConf ( Configuration conf, ZooKeeperWatcher zk )  :  void
ReplicationLogCleaner.setConf ( Configuration conf, ZooKeeperWatcher zk, ReplicationQueuesClient replicationQueuesClient )  :  void

hbase-server-1.6.0.jar, WALPrettyPrinter.class
package org.apache.hadoop.hbase.wal
WALPrettyPrinter.WALPrettyPrinter ( boolean outputValues, boolean outputJSON, long sequence, String table, String region, String row, boolean persistentOutput, PrintStream out )

hbase-server-1.6.0.jar, ZkCoordinatedStateManager.class
package org.apache.hadoop.hbase.coordination
ZkCoordinatedStateManager.getTableStateManager ( )  :  TableStateManager

hbase-thrift-1.6.0.jar, ThriftServer.class
package org.apache.hadoop.hbase.thrift
ThriftServer.main ( String[ ] args ) [static]  :  void
ThriftServer.stop ( )  :  void
ThriftServer.ThriftServer ( Configuration conf )

hbase-thrift-1.6.0.jar, ThriftServer.class
package org.apache.hadoop.hbase.thrift2
ThriftServer.main ( String[ ] args ) [static]  :  void
ThriftServer.registerFilters ( Configuration conf ) [static]  :  void
ThriftServer.ThriftServer ( )

to the top

Problems with Data Types, High Severity  15 


hbase-client-1.6.0.jar
package org.apache.hadoop.hbase.client
[+] interface Admin  2 
[+] interface Connection  1 
[+] interface HConnection  1 

hbase-rest-1.6.0.jar
package org.apache.hadoop.hbase.rest.client
[+] class RemoteAdmin  1 
[+] class RemoteHTable  1 

hbase-server-1.6.0.jar
package org.apache.hadoop.hbase.coprocessor
[+] interface MasterObserver  2 

hbase-server-1.6.0.jar
package org.apache.hadoop.hbase.ipc
[+] interface RpcServerInterface  2 

hbase-server-1.6.0.jar
package org.apache.hadoop.hbase.regionserver
[+] class HRegionServer  1 
[+] interface Store  2 

hbase-thrift-1.6.0.jar
package org.apache.hadoop.hbase.thrift
[+] class ThriftServer  1 

hbase-thrift-1.6.0.jar
package org.apache.hadoop.hbase.thrift2
[+] class ThriftServer  1 

to the top

Problems with Methods, Medium Severity  1 


hbase-server-1.6.0.jar, HRegionServer.class
package org.apache.hadoop.hbase.regionserver
[+] HRegionServer.getRegionBlockLocations ( String encodedRegionName )  :  InetSocketAddress[ ]  1 

to the top

Other Changes in Data Types  7 


hbase-client-1.6.0.jar
package org.apache.hadoop.hbase
[+] class HTableDescriptor  2 

hbase-client-1.6.0.jar
package org.apache.hadoop.hbase.filter
[+] class ParseConstants  1 

hbase-client-1.6.0.jar
package org.apache.hadoop.hbase.replication
[+] class ReplicationPeerConfig  1 

hbase-server-1.6.0.jar
package org.apache.hadoop.hbase.mapreduce
[+] class HFileOutputFormat2  3 

to the top

Java Archives  18 


hbase-annotations-1.6.0.jar
hbase-client-1.6.0.jar
hbase-client-project-1.6.0.jar
hbase-common-1.6.0.jar
hbase-examples-1.6.0.jar
hbase-external-blockcache-1.6.0.jar
hbase-hadoop-compat-1.6.0.jar
hbase-hadoop2-compat-1.6.0.jar
hbase-hbtop-1.6.0.jar
hbase-metrics-api-1.6.0.jar
hbase-prefix-tree-1.6.0.jar
hbase-procedure-1.6.0.jar
hbase-protocol-1.6.0.jar
hbase-rest-1.6.0.jar
hbase-rsgroup-1.6.0.jar
hbase-server-1.6.0.jar
hbase-shaded-client-project-1.6.0.jar
hbase-thrift-1.6.0.jar

to the top