The following document contains the results of Checkstyle 5.7. rss feed

Summary

Files  Info  Warnings  Errors
1830 0 0 4257

Files

File  I  W  E
maven-archiver/pom.properties 0 0 1
org/apache/hadoop/hbase/AuthUtil.java 0 0 1
org/apache/hadoop/hbase/CellScanner.java 0 0 1
org/apache/hadoop/hbase/CellUtil.java 0 0 4
org/apache/hadoop/hbase/CompoundConfiguration.java 0 0 4
org/apache/hadoop/hbase/CoordinatedStateManagerFactory.java 0 0 1
org/apache/hadoop/hbase/DaemonThreadFactory.java 0 0 3
org/apache/hadoop/hbase/DoNotRetryIOException.java 0 0 1
org/apache/hadoop/hbase/HBaseConfiguration.java 0 0 2
org/apache/hadoop/hbase/HBaseInterfaceAudience.java 0 0 1
org/apache/hadoop/hbase/HConstants.java 0 0 15
org/apache/hadoop/hbase/HRegionInfo.java 0 0 2
org/apache/hadoop/hbase/HRegionLocation.java 0 0 1
org/apache/hadoop/hbase/HTableDescriptor.java 0 0 9
org/apache/hadoop/hbase/HealthChecker.java 0 0 1
org/apache/hadoop/hbase/JMXListener.java 0 0 2
org/apache/hadoop/hbase/KeyValue.java 0 0 14
org/apache/hadoop/hbase/KeyValueTestUtil.java 0 0 1
org/apache/hadoop/hbase/KeyValueUtil.java 0 0 3
org/apache/hadoop/hbase/LocalHBaseCluster.java 0 0 2
org/apache/hadoop/hbase/MetaMigrationConvertingToPB.java 0 0 1
org/apache/hadoop/hbase/MetaMutationAnnotation.java 0 0 1
org/apache/hadoop/hbase/MetaTableAccessor.java 0 0 4
org/apache/hadoop/hbase/NamespaceDescriptor.java 0 0 2
org/apache/hadoop/hbase/PleaseHoldException.java 0 0 1
org/apache/hadoop/hbase/RegionException.java 0 0 1
org/apache/hadoop/hbase/RegionLoad.java 0 0 1
org/apache/hadoop/hbase/RegionLocations.java 0 0 1
org/apache/hadoop/hbase/RegionTransition.java 0 0 2
org/apache/hadoop/hbase/RemoteExceptionHandler.java 0 0 7
org/apache/hadoop/hbase/ScheduledChore.java 0 0 1
org/apache/hadoop/hbase/ServerLoad.java 0 0 1
org/apache/hadoop/hbase/ServerName.java 0 0 2
org/apache/hadoop/hbase/SplitLogCounters.java 0 0 1
org/apache/hadoop/hbase/TableExistsException.java 0 0 1
org/apache/hadoop/hbase/TableInfoMissingException.java 0 0 6
org/apache/hadoop/hbase/TableName.java 0 0 2
org/apache/hadoop/hbase/TableNotDisabledException.java 0 0 1
org/apache/hadoop/hbase/TableNotEnabledException.java 0 0 1
org/apache/hadoop/hbase/TableNotFoundException.java 0 0 1
org/apache/hadoop/hbase/TagRewriteCell.java 0 0 5
org/apache/hadoop/hbase/TagType.java 0 0 1
org/apache/hadoop/hbase/VersionAnnotation.java 0 0 1
org/apache/hadoop/hbase/ZNodeClearer.java 0 0 1
org/apache/hadoop/hbase/backup/BackupDriver.java 0 0 1
org/apache/hadoop/hbase/backup/BackupInfo.java 0 0 3
org/apache/hadoop/hbase/backup/BackupRequest.java 0 0 1
org/apache/hadoop/hbase/backup/BackupRestoreClientFactory.java 0 0 1
org/apache/hadoop/hbase/backup/BackupRestoreServerFactory.java 0 0 1
org/apache/hadoop/hbase/backup/HBackupFileSystem.java 0 0 1
org/apache/hadoop/hbase/backup/HFileArchiver.java 0 0 4
org/apache/hadoop/hbase/backup/RestoreDriver.java 0 0 2
org/apache/hadoop/hbase/backup/example/LongTermArchivingHFileCleaner.java 0 0 2
org/apache/hadoop/hbase/backup/example/TableHFileArchiveTracker.java 0 0 1
org/apache/hadoop/hbase/backup/impl/BackupCommands.java 0 0 12
org/apache/hadoop/hbase/backup/impl/BackupManifest.java 0 0 2
org/apache/hadoop/hbase/backup/impl/BackupRestoreConstants.java 0 0 1
org/apache/hadoop/hbase/backup/impl/BackupSystemTable.java 0 0 6
org/apache/hadoop/hbase/backup/impl/BackupSystemTableHelper.java 0 0 3
org/apache/hadoop/hbase/backup/mapreduce/MapReduceBackupCopyService.java 0 0 6
org/apache/hadoop/hbase/backup/master/FullTableBackupProcedure.java 0 0 6
org/apache/hadoop/hbase/backup/master/IncrementalTableBackupProcedure.java 0 0 3
org/apache/hadoop/hbase/backup/master/LogRollMasterProcedureManager.java 0 0 1
org/apache/hadoop/hbase/backup/regionserver/LogRollBackupSubprocedure.java 0 0 1
org/apache/hadoop/hbase/backup/regionserver/LogRollRegionServerProcedureManager.java 0 0 1
org/apache/hadoop/hbase/backup/util/BackupServerUtil.java 0 0 1
org/apache/hadoop/hbase/backup/util/RestoreServerUtil.java 0 0 6
org/apache/hadoop/hbase/classification/InterfaceAudience.java 0 0 1
org/apache/hadoop/hbase/classification/tools/ExcludePrivateAnnotationsStandardDoclet.java 0 0 1
org/apache/hadoop/hbase/classification/tools/IncludePublicAnnotationsStandardDoclet.java 0 0 1
org/apache/hadoop/hbase/classification/tools/RootDocProcessor.java 0 0 3
org/apache/hadoop/hbase/classification/tools/StabilityOptions.java 0 0 1
org/apache/hadoop/hbase/client/AbstractClientScanner.java 0 0 2
org/apache/hadoop/hbase/client/Admin.java 0 0 2
org/apache/hadoop/hbase/client/Append.java 0 0 2
org/apache/hadoop/hbase/client/AsyncProcess.java 0 0 29
org/apache/hadoop/hbase/client/BufferedMutatorImpl.java 0 0 3
org/apache/hadoop/hbase/client/ClientIdGenerator.java 0 0 1
org/apache/hadoop/hbase/client/ClientScanner.java 0 0 24
org/apache/hadoop/hbase/client/ClientSideRegionScanner.java 0 0 2
org/apache/hadoop/hbase/client/ClientSmallReversedScanner.java 0 0 1
org/apache/hadoop/hbase/client/ClusterConnection.java 0 0 2
org/apache/hadoop/hbase/client/ClusterStatusListener.java 0 0 1
org/apache/hadoop/hbase/client/ConnectionAdapter.java 0 0 1
org/apache/hadoop/hbase/client/ConnectionManager.java 0 0 38
org/apache/hadoop/hbase/client/ConnectionUtils.java 0 0 2
org/apache/hadoop/hbase/client/DelegatingRetryingCallable.java 0 0 1
org/apache/hadoop/hbase/client/Delete.java 0 0 2
org/apache/hadoop/hbase/client/FailureInfo.java 0 0 4
org/apache/hadoop/hbase/client/HBaseAdmin.java 0 0 10
org/apache/hadoop/hbase/client/HBaseBackupAdmin.java 0 0 3
org/apache/hadoop/hbase/client/HConnectable.java 0 0 1
org/apache/hadoop/hbase/client/HConnection.java 0 0 17
org/apache/hadoop/hbase/client/HConnectionManager.java 0 0 13
org/apache/hadoop/hbase/client/HTable.java 0 0 15
org/apache/hadoop/hbase/client/HTableMultiplexer.java 0 0 8
org/apache/hadoop/hbase/client/HTablePool.java 0 0 7
org/apache/hadoop/hbase/client/HTableUtil.java 0 0 30
org/apache/hadoop/hbase/client/HTableWrapper.java 0 0 6
org/apache/hadoop/hbase/client/Increment.java 0 0 2
org/apache/hadoop/hbase/client/MasterCallable.java 0 0 2
org/apache/hadoop/hbase/client/MetaCache.java 0 0 2
org/apache/hadoop/hbase/client/MetaScanner.java 0 0 1
org/apache/hadoop/hbase/client/MultiAction.java 0 0 1
org/apache/hadoop/hbase/client/MultiServerCallable.java 0 0 1
org/apache/hadoop/hbase/client/Mutation.java 0 0 5
org/apache/hadoop/hbase/client/PreemptiveFastFailInterceptor.java 0 0 5
org/apache/hadoop/hbase/client/Put.java 0 0 2
org/apache/hadoop/hbase/client/Query.java 0 0 3
org/apache/hadoop/hbase/client/QuotaStatusCalls.java 0 0 4
org/apache/hadoop/hbase/client/RegionAdminServiceCallable.java 0 0 7
org/apache/hadoop/hbase/client/RegionReplicaUtil.java 0 0 1
org/apache/hadoop/hbase/client/RegionServerCallable.java 0 0 4
org/apache/hadoop/hbase/client/RegistryFactory.java 0 0 1
org/apache/hadoop/hbase/client/Result.java 0 0 8
org/apache/hadoop/hbase/client/RetriesExhaustedWithDetailsException.java 0 0 4
org/apache/hadoop/hbase/client/ReversedScannerCallable.java 0 0 5
org/apache/hadoop/hbase/client/RpcRetryingCallerFactory.java 0 0 1
org/apache/hadoop/hbase/client/RpcRetryingCallerWithReadReplicas.java 0 0 12
org/apache/hadoop/hbase/client/Scan.java 0 0 1
org/apache/hadoop/hbase/client/ScannerCallable.java 0 0 16
org/apache/hadoop/hbase/client/ScannerCallableWithReplicas.java 0 0 8
org/apache/hadoop/hbase/client/ServerStatisticTracker.java 0 0 2
org/apache/hadoop/hbase/client/Table.java 0 0 2
org/apache/hadoop/hbase/client/UnmodifyableHTableDescriptor.java 0 0 1
org/apache/hadoop/hbase/client/ZooKeeperRegistry.java 0 0 1
org/apache/hadoop/hbase/client/coprocessor/AggregationClient.java 0 0 13
org/apache/hadoop/hbase/client/coprocessor/Batch.java 0 0 4
org/apache/hadoop/hbase/client/coprocessor/LongColumnInterpreter.java 0 0 1
org/apache/hadoop/hbase/client/coprocessor/RowProcessorClient.java 0 0 1
org/apache/hadoop/hbase/client/coprocessor/SecureBulkLoadClient.java 0 0 3
org/apache/hadoop/hbase/client/coprocessor/package-info.java 0 0 10
org/apache/hadoop/hbase/client/metrics/ScanMetrics.java 0 0 9
org/apache/hadoop/hbase/client/replication/ReplicationAdmin.java 0 0 8
org/apache/hadoop/hbase/codec/BaseDecoder.java 0 0 1
org/apache/hadoop/hbase/codec/BaseEncoder.java 0 0 2
org/apache/hadoop/hbase/codec/KeyValueCodec.java 0 0 1
org/apache/hadoop/hbase/codec/KeyValueCodecWithTags.java 0 0 1
org/apache/hadoop/hbase/codec/prefixtree/PrefixTreeBlockMeta.java 0 0 35
org/apache/hadoop/hbase/codec/prefixtree/PrefixTreeCodec.java 0 0 4
org/apache/hadoop/hbase/codec/prefixtree/PrefixTreeSeeker.java 0 0 8
org/apache/hadoop/hbase/codec/prefixtree/decode/ArraySearcherPool.java 0 0 1
org/apache/hadoop/hbase/codec/prefixtree/decode/DecoderFactory.java 0 0 1
org/apache/hadoop/hbase/codec/prefixtree/decode/PrefixTreeArrayReversibleScanner.java 0 0 1
org/apache/hadoop/hbase/codec/prefixtree/decode/PrefixTreeArrayScanner.java 0 0 13
org/apache/hadoop/hbase/codec/prefixtree/decode/PrefixTreeArraySearcher.java 0 0 1
org/apache/hadoop/hbase/codec/prefixtree/decode/PrefixTreeCell.java 0 0 18
org/apache/hadoop/hbase/codec/prefixtree/decode/column/ColumnNodeReader.java 0 0 8
org/apache/hadoop/hbase/codec/prefixtree/decode/column/ColumnReader.java 0 0 6
org/apache/hadoop/hbase/codec/prefixtree/decode/row/RowNodeReader.java 0 0 20
org/apache/hadoop/hbase/codec/prefixtree/decode/timestamp/MvccVersionDecoder.java 0 0 2
org/apache/hadoop/hbase/codec/prefixtree/decode/timestamp/TimestampDecoder.java 0 0 2
org/apache/hadoop/hbase/codec/prefixtree/encode/EncoderFactory.java 0 0 1
org/apache/hadoop/hbase/codec/prefixtree/encode/PrefixTreeEncoder.java 0 0 36
org/apache/hadoop/hbase/codec/prefixtree/encode/column/ColumnNodeWriter.java 0 0 6
org/apache/hadoop/hbase/codec/prefixtree/encode/column/ColumnSectionWriter.java 0 0 1
org/apache/hadoop/hbase/codec/prefixtree/encode/other/CellTypeEncoder.java 0 0 3
org/apache/hadoop/hbase/codec/prefixtree/encode/other/LongEncoder.java 0 0 8
org/apache/hadoop/hbase/codec/prefixtree/encode/row/RowNodeWriter.java 0 0 8
org/apache/hadoop/hbase/codec/prefixtree/encode/row/RowSectionWriter.java 0 0 9
org/apache/hadoop/hbase/codec/prefixtree/encode/tokenize/Tokenizer.java 0 0 9
org/apache/hadoop/hbase/codec/prefixtree/encode/tokenize/TokenizerNode.java 0 0 11
org/apache/hadoop/hbase/codec/prefixtree/encode/tokenize/TokenizerRowSearchResult.java 0 0 2
org/apache/hadoop/hbase/codec/prefixtree/scanner/ReversibleCellScanner.java 0 0 2
org/apache/hadoop/hbase/constraint/package-info.java 0 0 61
org/apache/hadoop/hbase/coordination/ZKSplitLogManagerCoordination.java 0 0 3
org/apache/hadoop/hbase/coordination/ZKSplitTransactionCoordination.java 0 0 1
org/apache/hadoop/hbase/coordination/ZkCoordinatedStateManager.java 0 0 8
org/apache/hadoop/hbase/coordination/ZkRegionMergeCoordination.java 0 0 1
org/apache/hadoop/hbase/coordination/ZkSplitLogWorkerCoordination.java 0 0 4
org/apache/hadoop/hbase/coprocessor/AggregateImplementation.java 0 0 14
org/apache/hadoop/hbase/coprocessor/BaseMasterAndRegionObserver.java 0 0 3
org/apache/hadoop/hbase/coprocessor/BaseMasterObserver.java 0 0 3
org/apache/hadoop/hbase/coprocessor/BaseRegionObserver.java 0 0 1
org/apache/hadoop/hbase/coprocessor/CoprocessorException.java 0 0 1
org/apache/hadoop/hbase/coprocessor/CoprocessorHost.java 0 0 10
org/apache/hadoop/hbase/coprocessor/RegionObserver.java 0 0 7
org/apache/hadoop/hbase/coprocessor/example/BulkDeleteEndpoint.java 0 0 2
org/apache/hadoop/hbase/coprocessor/example/RowCountEndpoint.java 0 0 2
org/apache/hadoop/hbase/coprocessor/example/ZooKeeperScanPolicyObserver.java 0 0 3
org/apache/hadoop/hbase/coprocessor/package-info.java 0 0 1
org/apache/hadoop/hbase/errorhandling/ForeignExceptionDispatcher.java 0 0 2
org/apache/hadoop/hbase/errorhandling/TimeoutException.java 0 0 1
org/apache/hadoop/hbase/executor/EventHandler.java 0 0 3
org/apache/hadoop/hbase/executor/ExecutorService.java 0 0 7
org/apache/hadoop/hbase/filter/BitComparator.java 0 0 2
org/apache/hadoop/hbase/filter/ByteArrayComparable.java 0 0 1
org/apache/hadoop/hbase/filter/ColumnPaginationFilter.java 0 0 2
org/apache/hadoop/hbase/filter/ColumnPrefixFilter.java 0 0 1
org/apache/hadoop/hbase/filter/ColumnRangeFilter.java 0 0 4
org/apache/hadoop/hbase/filter/CompareFilter.java 0 0 3
org/apache/hadoop/hbase/filter/DependentColumnFilter.java 0 0 4
org/apache/hadoop/hbase/filter/FamilyFilter.java 0 0 2
org/apache/hadoop/hbase/filter/Filter.java 0 0 4
org/apache/hadoop/hbase/filter/FilterBase.java 0 0 2
org/apache/hadoop/hbase/filter/FilterList.java 0 0 2
org/apache/hadoop/hbase/filter/FilterWrapper.java 0 0 5
org/apache/hadoop/hbase/filter/FirstKeyValueMatchingQualifiersFilter.java 0 0 1
org/apache/hadoop/hbase/filter/FuzzyRowFilter.java 0 0 1
org/apache/hadoop/hbase/filter/InclusiveStopFilter.java 0 0 1
org/apache/hadoop/hbase/filter/KeyOnlyFilter.java 0 0 1
org/apache/hadoop/hbase/filter/MultipleColumnPrefixFilter.java 0 0 6
org/apache/hadoop/hbase/filter/ParseConstants.java 0 0 1
org/apache/hadoop/hbase/filter/ParseFilter.java 0 0 22
org/apache/hadoop/hbase/filter/PrefixFilter.java 0 0 3
org/apache/hadoop/hbase/filter/RandomRowFilter.java 0 0 2
org/apache/hadoop/hbase/filter/RegexStringComparator.java 0 0 1
org/apache/hadoop/hbase/filter/SingleColumnValueExcludeFilter.java 0 0 1
org/apache/hadoop/hbase/filter/SingleColumnValueFilter.java 0 0 9
org/apache/hadoop/hbase/filter/TimestampsFilter.java 0 0 3
org/apache/hadoop/hbase/fs/HFileSystem.java 0 0 1
org/apache/hadoop/hbase/http/HtmlQuoting.java 0 0 2
org/apache/hadoop/hbase/http/HttpRequestLog.java 0 0 1
org/apache/hadoop/hbase/http/HttpServer.java 0 0 25
org/apache/hadoop/hbase/http/InfoServer.java 0 0 1
org/apache/hadoop/hbase/http/ServerConfigurationKeys.java 0 0 1
org/apache/hadoop/hbase/http/jmx/JMXJsonServlet.java 0 0 7
org/apache/hadoop/hbase/http/log/LogLevel.java 0 0 4
org/apache/hadoop/hbase/io/BoundedByteBufferPool.java 0 0 2
org/apache/hadoop/hbase/io/ByteBufferOutputStream.java 0 0 1
org/apache/hadoop/hbase/io/DataOutputOutputStream.java 0 0 1
org/apache/hadoop/hbase/io/FSDataInputStreamWrapper.java 0 0 4
org/apache/hadoop/hbase/io/FileLink.java 0 0 2
org/apache/hadoop/hbase/io/HalfStoreFileReader.java 0 0 7
org/apache/hadoop/hbase/io/compress/Compression.java 0 0 2
org/apache/hadoop/hbase/io/crypto/Encryption.java 0 0 2
org/apache/hadoop/hbase/io/crypto/KeyStoreKeyProvider.java 0 0 3
org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.java 0 0 33
org/apache/hadoop/hbase/io/encoding/CompressionState.java 0 0 7
org/apache/hadoop/hbase/io/encoding/DataBlockEncoder.java 0 0 1
org/apache/hadoop/hbase/io/encoding/DiffKeyDeltaEncoder.java 0 0 2
org/apache/hadoop/hbase/io/encoding/EncodingState.java 0 0 1
org/apache/hadoop/hbase/io/encoding/FastDiffDeltaEncoder.java 0 0 8
org/apache/hadoop/hbase/io/encoding/HFileBlockDecodingContext.java 0 0 1
org/apache/hadoop/hbase/io/hfile/AbstractHFileReader.java 0 0 28
org/apache/hadoop/hbase/io/hfile/AbstractHFileWriter.java 0 0 17
org/apache/hadoop/hbase/io/hfile/BlockCacheKey.java 0 0 1
org/apache/hadoop/hbase/io/hfile/BlockCacheUtil.java 0 0 2
org/apache/hadoop/hbase/io/hfile/BlockCachesIterator.java 0 0 3
org/apache/hadoop/hbase/io/hfile/CacheConfig.java 0 0 3
org/apache/hadoop/hbase/io/hfile/CacheStats.java 0 0 1
org/apache/hadoop/hbase/io/hfile/CacheableDeserializerIdManager.java 0 0 1
org/apache/hadoop/hbase/io/hfile/ChecksumUtil.java 0 0 1
org/apache/hadoop/hbase/io/hfile/CombinedBlockCache.java 0 0 4
org/apache/hadoop/hbase/io/hfile/FixedFileTrailer.java 0 0 3
org/apache/hadoop/hbase/io/hfile/HFile.java 0 0 22
org/apache/hadoop/hbase/io/hfile/HFileBlock.java 0 0 13
org/apache/hadoop/hbase/io/hfile/HFileBlockIndex.java 0 0 2
org/apache/hadoop/hbase/io/hfile/HFilePrettyPrinter.java 0 0 13
org/apache/hadoop/hbase/io/hfile/HFileReaderV2.java 0 0 5
org/apache/hadoop/hbase/io/hfile/HFileReaderV3.java 0 0 2
org/apache/hadoop/hbase/io/hfile/HFileScanner.java 0 0 6
org/apache/hadoop/hbase/io/hfile/HFileUtil.java 0 0 2
org/apache/hadoop/hbase/io/hfile/HFileWriterV2.java 0 0 3
org/apache/hadoop/hbase/io/hfile/LruBlockCache.java 0 0 1
org/apache/hadoop/hbase/io/hfile/NoOpDataBlockEncoder.java 0 0 1
org/apache/hadoop/hbase/io/hfile/PrefetchExecutor.java 0 0 1
org/apache/hadoop/hbase/io/hfile/bucket/BucketAllocator.java 0 0 5
org/apache/hadoop/hbase/io/hfile/bucket/BucketCache.java 0 0 12
org/apache/hadoop/hbase/io/hfile/bucket/UniqueIndexMap.java 0 0 3
org/apache/hadoop/hbase/io/util/HeapMemorySizeUtil.java 0 0 2
org/apache/hadoop/hbase/io/util/LRUDictionary.java 0 0 7
org/apache/hadoop/hbase/io/util/StreamUtils.java 0 0 10
org/apache/hadoop/hbase/ipc/AbstractRpcClient.java 0 0 16
org/apache/hadoop/hbase/ipc/AdaptiveLifoCoDelCallQueue.java 0 0 1
org/apache/hadoop/hbase/ipc/AsyncCall.java 0 0 7
org/apache/hadoop/hbase/ipc/AsyncRpcChannel.java 0 0 7
org/apache/hadoop/hbase/ipc/AsyncRpcClient.java 0 0 4
org/apache/hadoop/hbase/ipc/BalancedQueueRpcExecutor.java 0 0 1
org/apache/hadoop/hbase/ipc/Call.java 0 0 10
org/apache/hadoop/hbase/ipc/ConnectionId.java 0 0 3
org/apache/hadoop/hbase/ipc/FastPathBalancedQueueRpcExecutor.java 0 0 3
org/apache/hadoop/hbase/ipc/MasterCoprocessorRpcChannel.java 0 0 4
org/apache/hadoop/hbase/ipc/MetricsHBaseServerSourceFactoryImpl.java 0 0 1
org/apache/hadoop/hbase/ipc/RegionCoprocessorRpcChannel.java 0 0 5
org/apache/hadoop/hbase/ipc/RegionServerCoprocessorRpcChannel.java 0 0 1
org/apache/hadoop/hbase/ipc/RemoteWithExtrasException.java 0 0 1
org/apache/hadoop/hbase/ipc/RpcClientImpl.java 0 0 17
org/apache/hadoop/hbase/ipc/RpcControllerFactory.java 0 0 1
org/apache/hadoop/hbase/ipc/RpcExecutor.java 0 0 3
org/apache/hadoop/hbase/ipc/RpcServer.java 0 0 55
org/apache/hadoop/hbase/ipc/ServerRpcController.java 0 0 2
org/apache/hadoop/hbase/ipc/SimpleRpcScheduler.java 0 0 3
org/apache/hadoop/hbase/ipc/TimeLimitedRpcController.java 0 0 4
org/apache/hadoop/hbase/mapred/Driver.java 0 0 1
org/apache/hadoop/hbase/mapred/GroupingTableMap.java 0 0 1
org/apache/hadoop/hbase/mapred/HRegionPartitioner.java 0 0 1
org/apache/hadoop/hbase/mapred/TableInputFormat.java 0 0 1
org/apache/hadoop/hbase/mapred/TableMapReduceUtil.java 0 0 10
org/apache/hadoop/hbase/mapreduce/CellCounter.java 0 0 6
org/apache/hadoop/hbase/mapreduce/CellCreator.java 0 0 1
org/apache/hadoop/hbase/mapreduce/CopyTable.java 0 0 20
org/apache/hadoop/hbase/mapreduce/Driver.java 0 0 1
org/apache/hadoop/hbase/mapreduce/Export.java 0 0 4
org/apache/hadoop/hbase/mapreduce/GroupingTableMapper.java 0 0 1
org/apache/hadoop/hbase/mapreduce/HFileInputFormat.java 0 0 2
org/apache/hadoop/hbase/mapreduce/HFileOutputFormat.java 0 0 1
org/apache/hadoop/hbase/mapreduce/HFileOutputFormat2.java 0 0 5
org/apache/hadoop/hbase/mapreduce/HLogInputFormat.java 0 0 1
org/apache/hadoop/hbase/mapreduce/HRegionPartitioner.java 0 0 1
org/apache/hadoop/hbase/mapreduce/HashTable.java 0 0 14
org/apache/hadoop/hbase/mapreduce/Import.java 0 0 3
org/apache/hadoop/hbase/mapreduce/ImportTsv.java 0 0 9
org/apache/hadoop/hbase/mapreduce/IndexBuilder.java 0 0 2
org/apache/hadoop/hbase/mapreduce/JarFinder.java 0 0 1
org/apache/hadoop/hbase/mapreduce/KeyValueSortReducer.java 0 0 2
org/apache/hadoop/hbase/mapreduce/LoadIncrementalHFiles.java 0 0 8
org/apache/hadoop/hbase/mapreduce/MultiTableInputFormatBase.java 0 0 2
org/apache/hadoop/hbase/mapreduce/MultiTableOutputFormat.java 0 0 5
org/apache/hadoop/hbase/mapreduce/MultithreadedTableMapper.java 0 0 3
org/apache/hadoop/hbase/mapreduce/RowCounter.java 0 0 1
org/apache/hadoop/hbase/mapreduce/SampleUploader.java 0 0 2
org/apache/hadoop/hbase/mapreduce/SimpleTotalOrderPartitioner.java 0 0 2
org/apache/hadoop/hbase/mapreduce/SyncTable.java 0 0 19
org/apache/hadoop/hbase/mapreduce/TableInputFormatBase.java 0 0 6
org/apache/hadoop/hbase/mapreduce/TableMapReduceUtil.java 0 0 5
org/apache/hadoop/hbase/mapreduce/TableOutputFormat.java 0 0 2
org/apache/hadoop/hbase/mapreduce/TableRecordReaderImpl.java 0 0 1
org/apache/hadoop/hbase/mapreduce/TableSnapshotInputFormatImpl.java 0 0 1
org/apache/hadoop/hbase/mapreduce/TableSplit.java 0 0 1
org/apache/hadoop/hbase/mapreduce/TextSortReducer.java 0 0 1
org/apache/hadoop/hbase/mapreduce/TsvImporterMapper.java 0 0 7
org/apache/hadoop/hbase/mapreduce/WALInputFormat.java 0 0 3
org/apache/hadoop/hbase/mapreduce/WALPlayer.java 0 0 2
org/apache/hadoop/hbase/mapreduce/replication/VerifyReplication.java 0 0 9
org/apache/hadoop/hbase/master/ActiveMasterManager.java 0 0 3
org/apache/hadoop/hbase/master/AssignmentManager.java 0 0 21
org/apache/hadoop/hbase/master/AssignmentVerificationReport.java 0 0 2
org/apache/hadoop/hbase/master/BulkAssigner.java 0 0 1
org/apache/hadoop/hbase/master/CatalogJanitor.java 0 0 5
org/apache/hadoop/hbase/master/ClusterStatusPublisher.java 0 0 2
org/apache/hadoop/hbase/master/GeneralBulkAssigner.java 0 0 3
org/apache/hadoop/hbase/master/HMaster.java 0 0 25
org/apache/hadoop/hbase/master/HMasterCommandLine.java 0 0 1
org/apache/hadoop/hbase/master/MasterCoprocessorHost.java 0 0 4
org/apache/hadoop/hbase/master/MasterFileSystem.java 0 0 12
org/apache/hadoop/hbase/master/MasterRpcServices.java 0 0 5
org/apache/hadoop/hbase/master/MasterServices.java 0 0 1
org/apache/hadoop/hbase/master/MetricsAssignmentManagerSourceImpl.java 0 0 3
org/apache/hadoop/hbase/master/MetricsMaster.java 0 0 3
org/apache/hadoop/hbase/master/MetricsMasterProcSource.java 0 0 1
org/apache/hadoop/hbase/master/MetricsMasterQuotaSourceImpl.java 0 0 1
org/apache/hadoop/hbase/master/MetricsMasterSourceFactoryImpl.java 0 0 1
org/apache/hadoop/hbase/master/MetricsMasterSourceImpl.java 0 0 1
org/apache/hadoop/hbase/master/RegionPlacementMaintainer.java 0 0 9
org/apache/hadoop/hbase/master/RegionState.java 0 0 1
org/apache/hadoop/hbase/master/RegionStateStore.java 0 0 2
org/apache/hadoop/hbase/master/RegionStates.java 0 0 2
org/apache/hadoop/hbase/master/ServerManager.java 0 0 4
org/apache/hadoop/hbase/master/SplitLogManager.java 0 0 15
org/apache/hadoop/hbase/master/TableLockManager.java 0 0 10
org/apache/hadoop/hbase/master/TableNamespaceManager.java 0 0 2
org/apache/hadoop/hbase/master/balancer/BaseLoadBalancer.java 0 0 82
org/apache/hadoop/hbase/master/balancer/FavoredNodeLoadBalancer.java 0 0 1
org/apache/hadoop/hbase/master/balancer/LoadBalancerFactory.java 0 0 1
org/apache/hadoop/hbase/master/balancer/RegionLocationFinder.java 0 0 1
org/apache/hadoop/hbase/master/balancer/SimpleLoadBalancer.java 0 0 1
org/apache/hadoop/hbase/master/balancer/StochasticLoadBalancer.java 0 0 15
org/apache/hadoop/hbase/master/cleaner/BaseLogCleanerDelegate.java 0 0 1
org/apache/hadoop/hbase/master/cleaner/CleanerChore.java 0 0 5
org/apache/hadoop/hbase/master/cleaner/HFileCleaner.java 0 0 7
org/apache/hadoop/hbase/master/handler/ClosedRegionHandler.java 0 0 1
org/apache/hadoop/hbase/master/handler/CreateTableHandler.java 0 0 3
org/apache/hadoop/hbase/master/handler/DeleteTableHandler.java 0 0 1
org/apache/hadoop/hbase/master/handler/LogReplayHandler.java 0 0 3
org/apache/hadoop/hbase/master/handler/ServerShutdownHandler.java 0 0 8
org/apache/hadoop/hbase/master/handler/TableEventHandler.java 0 0 4
org/apache/hadoop/hbase/master/normalizer/SimpleRegionNormalizer.java 0 0 1
org/apache/hadoop/hbase/master/procedure/DeleteTableProcedure.java 0 0 1
org/apache/hadoop/hbase/master/procedure/DisableTableProcedure.java 0 0 1
org/apache/hadoop/hbase/master/procedure/MasterProcedureEnv.java 0 0 1
org/apache/hadoop/hbase/master/procedure/MasterProcedureUtil.java 0 0 1
org/apache/hadoop/hbase/master/snapshot/CloneSnapshotHandler.java 0 0 1
org/apache/hadoop/hbase/master/snapshot/DisabledTableSnapshotHandler.java 0 0 4
org/apache/hadoop/hbase/master/snapshot/MasterSnapshotVerifier.java 0 0 1
org/apache/hadoop/hbase/master/snapshot/SnapshotFileCache.java 0 0 4
org/apache/hadoop/hbase/master/snapshot/SnapshotManager.java 0 0 3
org/apache/hadoop/hbase/master/snapshot/TakeSnapshotHandler.java 0 0 15
org/apache/hadoop/hbase/metrics/BaseSourceImpl.java 0 0 8
org/apache/hadoop/hbase/migration/NamespaceUpgrade.java 0 0 1
org/apache/hadoop/hbase/migration/UpgradeTo96.java 0 0 1
org/apache/hadoop/hbase/mob/DefaultMobStoreCompactor.java 0 0 2
org/apache/hadoop/hbase/mob/DefaultMobStoreFlusher.java 0 0 1
org/apache/hadoop/hbase/mob/MobConstants.java 0 0 2
org/apache/hadoop/hbase/mob/MobFileCache.java 0 0 1
org/apache/hadoop/hbase/mob/MobFileName.java 0 0 1
org/apache/hadoop/hbase/mob/MobUtils.java 0 0 3
org/apache/hadoop/hbase/mob/compactions/MobCompactionRequest.java 0 0 2
org/apache/hadoop/hbase/mob/compactions/MobCompactor.java 0 0 7
org/apache/hadoop/hbase/mob/compactions/PartitionedMobCompactionRequest.java 0 0 3
org/apache/hadoop/hbase/mob/compactions/PartitionedMobCompactor.java 0 0 5
org/apache/hadoop/hbase/monitoring/MemoryBoundedLogMessageBuffer.java 0 0 2
org/apache/hadoop/hbase/monitoring/MonitoredTaskImpl.java 0 0 1
org/apache/hadoop/hbase/package-info.java 0 0 1
org/apache/hadoop/hbase/procedure/Procedure.java 0 0 8
org/apache/hadoop/hbase/procedure/ProcedureCoordinator.java 0 0 1
org/apache/hadoop/hbase/procedure/ProcedureManagerHost.java 0 0 1
org/apache/hadoop/hbase/procedure/ProcedureMemberRpcs.java 0 0 1
org/apache/hadoop/hbase/procedure/RegionServerProcedureManager.java 0 0 1
org/apache/hadoop/hbase/procedure/Subprocedure.java 0 0 4
org/apache/hadoop/hbase/procedure/ZKProcedureCoordinatorRpcs.java 0 0 6
org/apache/hadoop/hbase/procedure/ZKProcedureMemberRpcs.java 0 0 2
org/apache/hadoop/hbase/procedure/ZKProcedureUtil.java 0 0 4
org/apache/hadoop/hbase/procedure/flush/FlushTableSubprocedure.java 0 0 1
org/apache/hadoop/hbase/procedure/flush/RegionServerFlushTableProcedureManager.java 0 0 2
org/apache/hadoop/hbase/procedure2/ProcedureExecutor.java 0 0 3
org/apache/hadoop/hbase/procedure2/store/ProcedureStore.java 0 0 1
org/apache/hadoop/hbase/procedure2/store/wal/ProcedureWALFormatReader.java 0 0 1
org/apache/hadoop/hbase/protobuf/ProtobufUtil.java 0 0 13
org/apache/hadoop/hbase/protobuf/ReplicationProtbufUtil.java 0 0 1
org/apache/hadoop/hbase/protobuf/RequestConverter.java 0 0 2
org/apache/hadoop/hbase/protobuf/ResponseConverter.java 0 0 3
org/apache/hadoop/hbase/quotas/FileSystemUtilizationChore.java 0 0 6
org/apache/hadoop/hbase/quotas/NamespaceQuotaSnapshotStore.java 0 0 1
org/apache/hadoop/hbase/quotas/NoopQuotaLimiter.java 0 0 1
org/apache/hadoop/hbase/quotas/QuotaLimiter.java 0 0 1
org/apache/hadoop/hbase/quotas/QuotaLimiterFactory.java 0 0 1
org/apache/hadoop/hbase/quotas/QuotaObserverChore.java 0 0 4
org/apache/hadoop/hbase/quotas/QuotaSettingsFactory.java 0 0 1
org/apache/hadoop/hbase/quotas/QuotaSnapshotStore.java 0 0 1
org/apache/hadoop/hbase/quotas/QuotaTableUtil.java 0 0 4
org/apache/hadoop/hbase/quotas/RateLimiter.java 0 0 1
org/apache/hadoop/hbase/quotas/RegionServerSpaceQuotaManager.java 0 0 1
org/apache/hadoop/hbase/quotas/SpaceQuotaSnapshot.java 0 0 3
org/apache/hadoop/hbase/quotas/SpaceQuotaSnapshotNotifierFactory.java 0 0 1
org/apache/hadoop/hbase/quotas/SpaceViolationPolicyEnforcement.java 0 0 2
org/apache/hadoop/hbase/quotas/SpaceViolationPolicyEnforcementFactory.java 0 0 2
org/apache/hadoop/hbase/quotas/TableQuotaSnapshotStore.java 0 0 1
org/apache/hadoop/hbase/quotas/TimeBasedLimiter.java 0 0 1
org/apache/hadoop/hbase/quotas/policies/AbstractViolationPolicyEnforcement.java 0 0 3
org/apache/hadoop/hbase/quotas/policies/DefaultViolationPolicyEnforcement.java 0 0 1
org/apache/hadoop/hbase/quotas/policies/DisableTableViolationPolicyEnforcement.java 0 0 3
org/apache/hadoop/hbase/quotas/policies/MissingSnapshotViolationPolicyEnforcement.java 0 0 1
org/apache/hadoop/hbase/quotas/policies/NoInsertsViolationPolicyEnforcement.java 0 0 1
org/apache/hadoop/hbase/quotas/policies/NoWritesCompactionsViolationPolicyEnforcement.java 0 0 1
org/apache/hadoop/hbase/quotas/policies/NoWritesViolationPolicyEnforcement.java 0 0 1
org/apache/hadoop/hbase/regionserver/AbstractMultiFileWriter.java 0 0 2
org/apache/hadoop/hbase/regionserver/CompactionTool.java 0 0 5
org/apache/hadoop/hbase/regionserver/DefaultMemStore.java 0 0 19
org/apache/hadoop/hbase/regionserver/FlushPolicy.java 0 0 1
org/apache/hadoop/hbase/regionserver/FlushPolicyFactory.java 0 0 1
org/apache/hadoop/hbase/regionserver/FlushRequestListener.java 0 0 1
org/apache/hadoop/hbase/regionserver/HMobStore.java 0 0 6
org/apache/hadoop/hbase/regionserver/HRegion.java 0 0 79
org/apache/hadoop/hbase/regionserver/HRegionFileSystem.java 0 0 2
org/apache/hadoop/hbase/regionserver/HRegionServer.java 0 0 56
org/apache/hadoop/hbase/regionserver/HRegionServerCommandLine.java 0 0 1
org/apache/hadoop/hbase/regionserver/HStore.java 0 0 18
org/apache/hadoop/hbase/regionserver/HeapMemStoreLAB.java 0 0 2
org/apache/hadoop/hbase/regionserver/KeyPrefixRegionSplitPolicy.java 0 0 1
org/apache/hadoop/hbase/regionserver/KeyValueHeap.java 0 0 4
org/apache/hadoop/hbase/regionserver/Leases.java 0 0 5
org/apache/hadoop/hbase/regionserver/LogRoller.java 0 0 5
org/apache/hadoop/hbase/regionserver/LruHashMap.java 0 0 7
org/apache/hadoop/hbase/regionserver/MemStoreChunkPool.java 0 0 2
org/apache/hadoop/hbase/regionserver/MemStoreFlusher.java 0 0 5
org/apache/hadoop/hbase/regionserver/MetricsRegionServerSourceImpl.java 0 0 5
org/apache/hadoop/hbase/regionserver/MetricsRegionServerWrapperImpl.java 0 0 1
org/apache/hadoop/hbase/regionserver/MetricsTable.java 0 0 1
org/apache/hadoop/hbase/regionserver/MetricsTableAggregateSourceImpl.java 0 0 1
org/apache/hadoop/hbase/regionserver/MetricsTableLatenciesImpl.java 0 0 7
org/apache/hadoop/hbase/regionserver/MetricsTableSourceImpl.java 0 0 1
org/apache/hadoop/hbase/regionserver/MetricsTableWrapperAggregateImpl.java 0 0 11
org/apache/hadoop/hbase/regionserver/MetricsUserAggregate.java 0 0 1
org/apache/hadoop/hbase/regionserver/MetricsUserAggregateSourceImpl.java 0 0 1
org/apache/hadoop/hbase/regionserver/MultiRowMutationProcessor.java 0 0 3
org/apache/hadoop/hbase/regionserver/RSRpcServices.java 0 0 22
org/apache/hadoop/hbase/regionserver/RegionCoprocessorHost.java 0 0 7
org/apache/hadoop/hbase/regionserver/RegionMergeTransactionImpl.java 0 0 1
org/apache/hadoop/hbase/regionserver/RegionSplitPolicy.java 0 0 1
org/apache/hadoop/hbase/regionserver/ReversedMobStoreScanner.java 0 0 1
org/apache/hadoop/hbase/regionserver/ReversedRegionScannerImpl.java 0 0 1
org/apache/hadoop/hbase/regionserver/RpcSchedulerFactory.java 0 0 1
org/apache/hadoop/hbase/regionserver/ScanDeleteTracker.java 0 0 8
org/apache/hadoop/hbase/regionserver/ScanQueryMatcher.java 0 0 6
org/apache/hadoop/hbase/regionserver/ScannerContext.java 0 0 13
org/apache/hadoop/hbase/regionserver/ServerNonceManager.java 0 0 1
org/apache/hadoop/hbase/regionserver/ShutdownHook.java 0 0 2
org/apache/hadoop/hbase/regionserver/SimpleRpcSchedulerFactory.java 0 0 2
org/apache/hadoop/hbase/regionserver/SplitLogWorker.java 0 0 1
org/apache/hadoop/hbase/regionserver/SplitTransactionImpl.java 0 0 6
org/apache/hadoop/hbase/regionserver/StoreEngine.java 0 0 4
org/apache/hadoop/hbase/regionserver/StoreFile.java 0 0 18
org/apache/hadoop/hbase/regionserver/StoreFlusher.java 0 0 2
org/apache/hadoop/hbase/regionserver/StoreScanner.java 0 0 25
org/apache/hadoop/hbase/regionserver/StoreUtils.java 0 0 1
org/apache/hadoop/hbase/regionserver/StorefileRefresherChore.java 0 0 1
org/apache/hadoop/hbase/regionserver/StripeMultiFileWriter.java 0 0 4
org/apache/hadoop/hbase/regionserver/StripeStoreFileManager.java 0 0 4
org/apache/hadoop/hbase/regionserver/StripeStoreFlusher.java 0 0 2
org/apache/hadoop/hbase/regionserver/TimeRangeTracker.java 0 0 2
org/apache/hadoop/hbase/regionserver/compactions/AbstractMultiOutputCompactor.java 0 0 7
org/apache/hadoop/hbase/regionserver/compactions/CompactionConfiguration.java 0 0 2
org/apache/hadoop/hbase/regionserver/compactions/CompactionContext.java 0 0 1
org/apache/hadoop/hbase/regionserver/compactions/CompactionPolicy.java 0 0 2
org/apache/hadoop/hbase/regionserver/compactions/CompactionProgress.java 0 0 4
org/apache/hadoop/hbase/regionserver/compactions/CompactionRequest.java 0 0 1
org/apache/hadoop/hbase/regionserver/compactions/CompactionThroughputControllerFactory.java 0 0 1
org/apache/hadoop/hbase/regionserver/compactions/Compactor.java 0 0 16
org/apache/hadoop/hbase/regionserver/compactions/CurrentHourProvider.java 0 0 4
org/apache/hadoop/hbase/regionserver/compactions/DateTieredCompactor.java 0 0 2
org/apache/hadoop/hbase/regionserver/compactions/DefaultCompactor.java 0 0 6
org/apache/hadoop/hbase/regionserver/compactions/OffPeakHours.java 0 0 2
org/apache/hadoop/hbase/regionserver/compactions/PressureAwareCompactionThroughputController.java 0 0 1
org/apache/hadoop/hbase/regionserver/compactions/StripeCompactionPolicy.java 0 0 4
org/apache/hadoop/hbase/regionserver/compactions/StripeCompactor.java 0 0 7
org/apache/hadoop/hbase/regionserver/handler/FinishRegionRecoveringHandler.java 0 0 3
org/apache/hadoop/hbase/regionserver/handler/OpenPriorityRegionHandler.java 0 0 1
org/apache/hadoop/hbase/regionserver/handler/OpenRegionHandler.java 0 0 2
org/apache/hadoop/hbase/regionserver/handler/WALSplitterHandler.java 0 0 1
org/apache/hadoop/hbase/regionserver/snapshot/FlushSnapshotSubprocedure.java 0 0 2
org/apache/hadoop/hbase/regionserver/snapshot/RegionServerSnapshotManager.java 0 0 4
org/apache/hadoop/hbase/regionserver/wal/CompressionContext.java 0 0 6
org/apache/hadoop/hbase/regionserver/wal/Compressor.java 0 0 4
org/apache/hadoop/hbase/regionserver/wal/FSHLog.java 0 0 18
org/apache/hadoop/hbase/regionserver/wal/HLogPrettyPrinter.java 0 0 21
org/apache/hadoop/hbase/regionserver/wal/KeyValueCompression.java 0 0 2
org/apache/hadoop/hbase/regionserver/wal/MetricsWALSourceImpl.java 0 0 3
org/apache/hadoop/hbase/regionserver/wal/ProtobufLogReader.java 0 0 15
org/apache/hadoop/hbase/regionserver/wal/ProtobufLogWriter.java 0 0 4
org/apache/hadoop/hbase/regionserver/wal/ReaderBase.java 0 0 7
org/apache/hadoop/hbase/regionserver/wal/SequenceFileLogReader.java 0 0 7
org/apache/hadoop/hbase/regionserver/wal/WALActionsListener.java 0 0 1
org/apache/hadoop/hbase/regionserver/wal/WALCellCodec.java 0 0 3
org/apache/hadoop/hbase/regionserver/wal/WALCoprocessorHost.java 0 0 3
org/apache/hadoop/hbase/regionserver/wal/WALEdit.java 0 0 1
org/apache/hadoop/hbase/regionserver/wal/WALUtil.java 0 0 1
org/apache/hadoop/hbase/regionserver/wal/WriterBase.java 0 0 3
org/apache/hadoop/hbase/replication/BaseReplicationEndpoint.java 0 0 1
org/apache/hadoop/hbase/replication/ReplicationEndpoint.java 0 0 2
org/apache/hadoop/hbase/replication/ReplicationFactory.java 0 0 1
org/apache/hadoop/hbase/replication/ReplicationStateZKBase.java 0 0 10
org/apache/hadoop/hbase/replication/regionserver/MetricsReplicationGlobalSourceSource.java 0 0 3
org/apache/hadoop/hbase/replication/regionserver/MetricsReplicationSource.java 0 0 1
org/apache/hadoop/hbase/replication/regionserver/MetricsReplicationSourceFactoryImpl.java 0 0 1
org/apache/hadoop/hbase/replication/regionserver/MetricsSource.java 0 0 1
org/apache/hadoop/hbase/replication/regionserver/RegionReplicaReplicationEndpoint.java 0 0 14
org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.java 0 0 2
org/apache/hadoop/hbase/replication/regionserver/ReplicationSource.java 0 0 5
org/apache/hadoop/hbase/replication/regionserver/ReplicationSyncUp.java 0 0 2
org/apache/hadoop/hbase/rest/Constants.java 0 0 1
org/apache/hadoop/hbase/rest/ExistsResource.java 0 0 2
org/apache/hadoop/hbase/rest/MetricsREST.java 0 0 1
org/apache/hadoop/hbase/rest/MetricsRESTSourceImpl.java 0 0 8
org/apache/hadoop/hbase/rest/MultiRowResource.java 0 0 2
org/apache/hadoop/hbase/rest/NamespacesInstanceResource.java 0 0 2
org/apache/hadoop/hbase/rest/RESTServer.java 0 0 11
org/apache/hadoop/hbase/rest/RegionsResource.java 0 0 2
org/apache/hadoop/hbase/rest/ResourceBase.java 0 0 3
org/apache/hadoop/hbase/rest/RootResource.java 0 0 1
org/apache/hadoop/hbase/rest/RowResource.java 0 0 3
org/apache/hadoop/hbase/rest/RowSpec.java 0 0 4
org/apache/hadoop/hbase/rest/ScannerInstanceResource.java 0 0 4
org/apache/hadoop/hbase/rest/ScannerResource.java 0 0 1
org/apache/hadoop/hbase/rest/ScannerResultGenerator.java 0 0 1
org/apache/hadoop/hbase/rest/SchemaResource.java 0 0 3
org/apache/hadoop/hbase/rest/StorageClusterStatusResource.java 0 0 1
org/apache/hadoop/hbase/rest/StorageClusterVersionResource.java 0 0 1
org/apache/hadoop/hbase/rest/TableResource.java 0 0 1
org/apache/hadoop/hbase/rest/TableScanResource.java 0 0 5
org/apache/hadoop/hbase/rest/VersionResource.java 0 0 1
org/apache/hadoop/hbase/rest/client/Cluster.java 0 0 2
org/apache/hadoop/hbase/rest/client/RemoteAdmin.java 0 0 6
org/apache/hadoop/hbase/rest/client/RemoteHTable.java 0 0 11
org/apache/hadoop/hbase/rest/model/ScannerModel.java 0 0 23
org/apache/hadoop/hbase/rest/model/TableRegionModel.java 0 0 1
org/apache/hadoop/hbase/rest/provider/producer/PlainTextMessageBodyProducer.java 0 0 1
org/apache/hadoop/hbase/rsgroup/RSGroupInfoManagerImpl.java 0 0 2
org/apache/hadoop/hbase/security/AccessDeniedException.java 0 0 1
org/apache/hadoop/hbase/security/AuthMethod.java 0 0 3
org/apache/hadoop/hbase/security/EncryptionUtil.java 0 0 1
org/apache/hadoop/hbase/security/HBasePolicyProvider.java 0 0 1
org/apache/hadoop/hbase/security/HBaseSaslRpcClient.java 0 0 1
org/apache/hadoop/hbase/security/HBaseSaslRpcServer.java 0 0 1
org/apache/hadoop/hbase/security/SaslStatus.java 0 0 1
org/apache/hadoop/hbase/security/SaslUtil.java 0 0 2
org/apache/hadoop/hbase/security/SecureBulkLoadUtil.java 0 0 1
org/apache/hadoop/hbase/security/SecurityInfo.java 0 0 1
org/apache/hadoop/hbase/security/SecurityUtil.java 0 0 1
org/apache/hadoop/hbase/security/User.java 0 0 2
org/apache/hadoop/hbase/security/access/AccessControlClient.java 0 0 2
org/apache/hadoop/hbase/security/access/AccessControlConstants.java 0 0 1
org/apache/hadoop/hbase/security/access/AccessControlLists.java 0 0 2
org/apache/hadoop/hbase/security/access/AccessController.java 0 0 16
org/apache/hadoop/hbase/security/access/AuthResult.java 0 0 2
org/apache/hadoop/hbase/security/access/CodeToClassAndBackFor96Migration.java 0 0 2
org/apache/hadoop/hbase/security/access/CoprocessorWhitelistMasterObserver.java 0 0 2
org/apache/hadoop/hbase/security/access/HbaseObjectWritableFor96Migration.java 0 0 4
org/apache/hadoop/hbase/security/access/Permission.java 0 0 2
org/apache/hadoop/hbase/security/access/SecureBulkLoadEndpoint.java 0 0 3
org/apache/hadoop/hbase/security/access/TableAuthManager.java 0 0 2
org/apache/hadoop/hbase/security/access/ZKPermissionWatcher.java 0 0 3
org/apache/hadoop/hbase/security/token/AuthenticationTokenIdentifier.java 0 0 5
org/apache/hadoop/hbase/security/token/AuthenticationTokenSecretManager.java 0 0 2
org/apache/hadoop/hbase/security/token/TokenProvider.java 0 0 1
org/apache/hadoop/hbase/security/token/TokenUtil.java 0 0 2
org/apache/hadoop/hbase/security/visibility/DefaultVisibilityLabelServiceImpl.java 0 0 3
org/apache/hadoop/hbase/security/visibility/ExpressionParser.java 0 0 1
org/apache/hadoop/hbase/security/visibility/VisibilityClient.java 0 0 10
org/apache/hadoop/hbase/security/visibility/VisibilityConstants.java 0 0 1
org/apache/hadoop/hbase/security/visibility/VisibilityController.java 0 0 7
org/apache/hadoop/hbase/security/visibility/VisibilityLabelService.java 0 0 1
org/apache/hadoop/hbase/security/visibility/VisibilityLabelServiceManager.java 0 0 1
org/apache/hadoop/hbase/security/visibility/VisibilityLabelsCache.java 0 0 1
org/apache/hadoop/hbase/security/visibility/VisibilityLabelsValidator.java 0 0 1
org/apache/hadoop/hbase/security/visibility/VisibilityReplicationEndpoint.java 0 0 3
org/apache/hadoop/hbase/security/visibility/VisibilityUtils.java 0 0 1
org/apache/hadoop/hbase/snapshot/ClientSnapshotDescriptionUtils.java 0 0 2
org/apache/hadoop/hbase/snapshot/ExportSnapshot.java 0 0 6
org/apache/hadoop/hbase/snapshot/SnapshotDescriptionUtils.java 0 0 4
org/apache/hadoop/hbase/snapshot/SnapshotInfo.java 0 0 5
org/apache/hadoop/hbase/snapshot/SnapshotManifest.java 0 0 1
org/apache/hadoop/hbase/snapshot/SnapshotManifestV1.java 0 0 2
org/apache/hadoop/hbase/snapshot/SnapshotManifestV2.java 0 0 1
org/apache/hadoop/hbase/snapshot/SnapshotReferenceUtil.java 0 0 2
org/apache/hadoop/hbase/spark/SparkSQLPushDownFilter.java 0 0 5
org/apache/hadoop/hbase/thrift/CallQueue.java 0 0 3
org/apache/hadoop/hbase/thrift/DemoClient.java 0 0 20
org/apache/hadoop/hbase/thrift/HbaseHandlerMetricsProxy.java 0 0 1
org/apache/hadoop/hbase/thrift/HttpDoAsClient.java 0 0 6
org/apache/hadoop/hbase/thrift/IncrementCoalescer.java 0 0 5
org/apache/hadoop/hbase/thrift/MetricsThriftServerSourceFactory.java 0 0 1
org/apache/hadoop/hbase/thrift/MetricsThriftServerSourceFactoryImpl.java 0 0 2
org/apache/hadoop/hbase/thrift/MetricsThriftServerSourceImpl.java 0 0 1
org/apache/hadoop/hbase/thrift/TBoundedThreadPoolServer.java 0 0 5
org/apache/hadoop/hbase/thrift/ThriftHttpServlet.java 0 0 3
org/apache/hadoop/hbase/thrift/ThriftMetrics.java 0 0 3
org/apache/hadoop/hbase/thrift/ThriftServer.java 0 0 1
org/apache/hadoop/hbase/thrift/ThriftServerRunner.java 0 0 18
org/apache/hadoop/hbase/thrift/ThriftUtilities.java 0 0 2
org/apache/hadoop/hbase/thrift2/DemoClient.java 0 0 1
org/apache/hadoop/hbase/thrift2/ThriftHBaseServiceHandler.java 0 0 1
org/apache/hadoop/hbase/thrift2/ThriftServer.java 0 0 14
org/apache/hadoop/hbase/thrift2/ThriftUtilities.java 0 0 2
org/apache/hadoop/hbase/tmpl/common/TaskMonitorTmpl.java 0 0 9
org/apache/hadoop/hbase/tmpl/common/TaskMonitorTmplImpl.java 0 0 18
org/apache/hadoop/hbase/tmpl/master/AssignmentManagerStatusTmpl.java 0 0 11
org/apache/hadoop/hbase/tmpl/master/AssignmentManagerStatusTmplImpl.java 0 0 17
org/apache/hadoop/hbase/tmpl/master/BackupMasterStatusTmpl.java 0 0 6
org/apache/hadoop/hbase/tmpl/master/BackupMasterStatusTmplImpl.java 0 0 17
org/apache/hadoop/hbase/tmpl/master/MasterStatusTmpl.java 0 0 50
org/apache/hadoop/hbase/tmpl/master/MasterStatusTmplImpl.java 0 0 133
org/apache/hadoop/hbase/tmpl/master/RegionServerListTmpl.java 0 0 12
org/apache/hadoop/hbase/tmpl/master/RegionServerListTmplImpl.java 0 0 52
org/apache/hadoop/hbase/tmpl/regionserver/BlockCacheTmpl.java 0 0 14
org/apache/hadoop/hbase/tmpl/regionserver/BlockCacheTmplImpl.java 0 0 93
org/apache/hadoop/hbase/tmpl/regionserver/BlockCacheViewTmpl.java 0 0 15
org/apache/hadoop/hbase/tmpl/regionserver/BlockCacheViewTmplImpl.java 0 0 16
org/apache/hadoop/hbase/tmpl/regionserver/RSStatusTmpl.java 0 0 13
org/apache/hadoop/hbase/tmpl/regionserver/RSStatusTmplImpl.java 0 0 56
org/apache/hadoop/hbase/tmpl/regionserver/RegionListTmpl.java 0 0 16
org/apache/hadoop/hbase/tmpl/regionserver/RegionListTmplImpl.java 0 0 62
org/apache/hadoop/hbase/tmpl/regionserver/ServerMetricsTmpl.java 0 0 17
org/apache/hadoop/hbase/tmpl/regionserver/ServerMetricsTmplImpl.java 0 0 61
org/apache/hadoop/hbase/tool/Canary.java 0 0 10
org/apache/hadoop/hbase/trace/SpanReceiverHost.java 0 0 2
org/apache/hadoop/hbase/types/CopyOnWriteArrayMap.java 0 0 5
org/apache/hadoop/hbase/types/FixedLengthWrapper.java 0 0 2
org/apache/hadoop/hbase/types/OrderedBytesBase.java 0 0 1
org/apache/hadoop/hbase/types/PBType.java 0 0 2
org/apache/hadoop/hbase/types/RawBytes.java 0 0 1
org/apache/hadoop/hbase/types/RawString.java 0 0 1
org/apache/hadoop/hbase/types/Struct.java 0 0 3
org/apache/hadoop/hbase/types/StructBuilder.java 0 0 1
org/apache/hadoop/hbase/types/StructIterator.java 0 0 3
org/apache/hadoop/hbase/types/TerminatedWrapper.java 0 0 2
org/apache/hadoop/hbase/types/Union2.java 0 0 2
org/apache/hadoop/hbase/types/Union3.java 0 0 1
org/apache/hadoop/hbase/types/Union4.java 0 0 1
org/apache/hadoop/hbase/util/AbstractByteRange.java 0 0 4
org/apache/hadoop/hbase/util/AbstractFileStatusFilter.java 0 0 1
org/apache/hadoop/hbase/util/AbstractHBaseTool.java 0 0 3
org/apache/hadoop/hbase/util/AbstractPositionedByteRange.java 0 0 2
org/apache/hadoop/hbase/util/Addressing.java 0 0 1
org/apache/hadoop/hbase/util/ArrayUtils.java 0 0 1
org/apache/hadoop/hbase/util/AtomicUtils.java 0 0 1
org/apache/hadoop/hbase/util/Base64.java 0 0 6
org/apache/hadoop/hbase/util/BoundedConcurrentLinkedQueue.java 0 0 1
org/apache/hadoop/hbase/util/ByteBloomFilter.java 0 0 9
org/apache/hadoop/hbase/util/ByteBufferArray.java 0 0 2
org/apache/hadoop/hbase/util/ByteBufferUtils.java 0 0 11
org/apache/hadoop/hbase/util/ByteRangeUtils.java 0 0 1
org/apache/hadoop/hbase/util/ByteStringer.java 0 0 1
org/apache/hadoop/hbase/util/Bytes.java 0 0 9
org/apache/hadoop/hbase/util/ChecksumFactory.java 0 0 2
org/apache/hadoop/hbase/util/ChecksumType.java 0 0 1
org/apache/hadoop/hbase/util/ClassLoaderBase.java 0 0 1
org/apache/hadoop/hbase/util/ClassSize.java 0 0 2
org/apache/hadoop/hbase/util/Classes.java 0 0 1
org/apache/hadoop/hbase/util/CollectionBackedScanner.java 0 0 1
org/apache/hadoop/hbase/util/CollectionUtils.java 0 0 1
org/apache/hadoop/hbase/util/CompoundBloomFilterBase.java 0 0 7
org/apache/hadoop/hbase/util/CompoundBloomFilterWriter.java 0 0 3
org/apache/hadoop/hbase/util/CompressionTest.java 0 0 3
org/apache/hadoop/hbase/util/ConcatenatedLists.java 0 0 5
org/apache/hadoop/hbase/util/ConfigUtil.java 0 0 1
org/apache/hadoop/hbase/util/ConnectionCache.java 0 0 3
org/apache/hadoop/hbase/util/CoprocessorClassLoader.java 0 0 1
org/apache/hadoop/hbase/util/Counter.java 0 0 17
org/apache/hadoop/hbase/util/DNS.java 0 0 1
org/apache/hadoop/hbase/util/DirectMemoryUtils.java 0 0 1
org/apache/hadoop/hbase/util/EncryptionTest.java 0 0 1
org/apache/hadoop/hbase/util/EnvironmentEdgeManager.java 0 0 1
org/apache/hadoop/hbase/util/ExceptionUtil.java 0 0 1
org/apache/hadoop/hbase/util/FSRegionScanner.java 0 0 1
org/apache/hadoop/hbase/util/FSTableDescriptorMigrationToSubdir.java 0 0 1
org/apache/hadoop/hbase/util/FSTableDescriptors.java 0 0 4
org/apache/hadoop/hbase/util/FSUtils.java 0 0 25
org/apache/hadoop/hbase/util/FSVisitor.java 0 0 4
org/apache/hadoop/hbase/util/GetJavaProperty.java 0 0 2
org/apache/hadoop/hbase/util/HBaseConfTool.java 0 0 2
org/apache/hadoop/hbase/util/HBaseFsck.java 0 0 82
org/apache/hadoop/hbase/util/HBaseFsckRepair.java 0 0 6
org/apache/hadoop/hbase/util/HFileArchiveUtil.java 0 0 1
org/apache/hadoop/hbase/util/HFileV1Detector.java 0 0 2
org/apache/hadoop/hbase/util/HMerge.java 0 0 6
org/apache/hadoop/hbase/util/HttpServerUtil.java 0 0 1
org/apache/hadoop/hbase/util/IdLock.java 0 0 1
org/apache/hadoop/hbase/util/IterableUtils.java 0 0 1
org/apache/hadoop/hbase/util/JVM.java 0 0 6
org/apache/hadoop/hbase/util/JVMClusterUtil.java 0 0 2
org/apache/hadoop/hbase/util/JenkinsHash.java 0 0 4
org/apache/hadoop/hbase/util/JvmPauseMonitor.java 0 0 1
org/apache/hadoop/hbase/util/MBeanUtil.java 0 0 6
org/apache/hadoop/hbase/util/MD5Hash.java 0 0 1
org/apache/hadoop/hbase/util/ManualEnvironmentEdge.java 0 0 2
org/apache/hadoop/hbase/util/MapreduceDependencyClasspathTool.java 0 0 2
org/apache/hadoop/hbase/util/Merge.java 0 0 3
org/apache/hadoop/hbase/util/Methods.java 0 0 1
org/apache/hadoop/hbase/util/MurmurHash3.java 0 0 1
org/apache/hadoop/hbase/util/OrderedBytes.java 0 0 8
org/apache/hadoop/hbase/util/Pair.java 0 0 2
org/apache/hadoop/hbase/util/PoolMap.java 0 0 4
org/apache/hadoop/hbase/util/PrettyPrinter.java 0 0 2
org/apache/hadoop/hbase/util/ProtoUtil.java 0 0 4
org/apache/hadoop/hbase/util/ReflectionUtils.java 0 0 1
org/apache/hadoop/hbase/util/RegionSplitter.java 0 0 10
org/apache/hadoop/hbase/util/RetryCounter.java 0 0 1
org/apache/hadoop/hbase/util/ServerCommandLine.java 0 0 1
org/apache/hadoop/hbase/util/ShutdownHookManager.java 0 0 1
org/apache/hadoop/hbase/util/SimpleByteRange.java 0 0 1
org/apache/hadoop/hbase/util/SimpleMutableByteRange.java 0 0 1
org/apache/hadoop/hbase/util/Strings.java 0 0 1
org/apache/hadoop/hbase/util/Threads.java 0 0 3
org/apache/hadoop/hbase/util/UnsafeAccess.java 0 0 1
org/apache/hadoop/hbase/util/VersionInfo.java 0 0 5
org/apache/hadoop/hbase/util/WeakObjectPool.java 0 0 1
org/apache/hadoop/hbase/util/Writables.java 0 0 1
org/apache/hadoop/hbase/util/ZKDataMigrator.java 0 0 1
org/apache/hadoop/hbase/util/byterange/ByteRangeSet.java 0 0 12
org/apache/hadoop/hbase/util/hbck/HFileCorruptionChecker.java 0 0 17
org/apache/hadoop/hbase/util/hbck/OfflineMetaRepair.java 0 0 1
org/apache/hadoop/hbase/util/hbck/TableIntegrityErrorHandlerImpl.java 0 0 1
org/apache/hadoop/hbase/util/hbck/TableLockChecker.java 0 0 2
org/apache/hadoop/hbase/util/test/RedundantKVGenerator.java 0 0 16
org/apache/hadoop/hbase/util/vint/UFIntTool.java 0 0 2
org/apache/hadoop/hbase/util/vint/UVIntTool.java 0 0 1
org/apache/hadoop/hbase/util/vint/UVLongTool.java 0 0 1
org/apache/hadoop/hbase/wal/DefaultWALProvider.java 0 0 4
org/apache/hadoop/hbase/wal/DisabledWALProvider.java 0 0 7
org/apache/hadoop/hbase/wal/RegionGroupingProvider.java 0 0 3
org/apache/hadoop/hbase/wal/WAL.java 0 0 1
org/apache/hadoop/hbase/wal/WALFactory.java 0 0 5
org/apache/hadoop/hbase/wal/WALKey.java 0 0 10
org/apache/hadoop/hbase/wal/WALProvider.java 0 0 1
org/apache/hadoop/hbase/wal/WALSplitter.java 0 0 49
org/apache/hadoop/hbase/zookeeper/EmptyWatcher.java 0 0 1
org/apache/hadoop/hbase/zookeeper/HQuorumPeer.java 0 0 4
org/apache/hadoop/hbase/zookeeper/InstancePending.java 0 0 1
org/apache/hadoop/hbase/zookeeper/MetaTableLocator.java 0 0 13
org/apache/hadoop/hbase/zookeeper/RecoverableZooKeeper.java 0 0 1
org/apache/hadoop/hbase/zookeeper/RegionServerTracker.java 0 0 3
org/apache/hadoop/hbase/zookeeper/ZKAssign.java 0 0 1
org/apache/hadoop/hbase/zookeeper/ZKServerTool.java 0 0 2
org/apache/hadoop/hbase/zookeeper/ZKSplitLog.java 0 0 3
org/apache/hadoop/hbase/zookeeper/ZKTableStateClientSideReader.java 0 0 1
org/apache/hadoop/hbase/zookeeper/ZKTableStateManager.java 0 0 2
org/apache/hadoop/hbase/zookeeper/ZKUtil.java 0 0 9
org/apache/hadoop/hbase/zookeeper/ZooKeeperListener.java 0 0 1
org/apache/hadoop/hbase/zookeeper/ZooKeeperMainServer.java 0 0 3
org/apache/hadoop/hbase/zookeeper/ZooKeeperNodeTracker.java 0 0 3
org/apache/hadoop/hbase/zookeeper/ZooKeeperWatcher.java 0 0 18
org/apache/hadoop/hbase/zookeeper/lock/ZKInterProcessLockBase.java 0 0 9
org/apache/hadoop/metrics2/impl/JmxCacheBuster.java 0 0 1
org/apache/hadoop/metrics2/lib/MutableHistogram.java 0 0 4
org/apache/hadoop/metrics2/util/MetricQuantile.java 0 0 2
org/apache/hadoop/metrics2/util/MetricSampleQuantiles.java 0 0 4
test-classes/org/apache/hadoop/hbase/PerformanceEvaluation_Counter.properties 0 0 1

Rules

Category Rule Violations Severity
annotation MissingDeprecated 184  Error
blocks EmptyBlock 99  Error
coding EmptyStatement 11  Error
EqualsHashCode 8  Error
InnerAssignment 55  Error
MissingSwitchDefault 19  Error
NoFinalizer 1  Error
design FinalClass 60  Error
HideUtilityClassConstructor 115  Error
InterfaceIsType 6  Error
VisibilityModifier 1854  Error
imports AvoidStarImport 30  Error
RedundantImport 92  Error
UnusedImports 328  Error
misc ArrayTypeStyle 48  Error
UpperEll 47  Error
sizes LineLength
  • max: "100"
  • ignorePattern: "^package.*|^import.*|a href|href|http://|https://|ftp://"
999  Error
MethodLength 45  Error
whitespace FileTabCharacter 18  Error
MethodParamPad 67  Error
ParenPad 170  Error

Details

maven-archiver/pom.properties

Severity Category Rule Message Line
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 23

org/apache/hadoop/hbase/AuthUtil.java

Severity Category Rule Message Line
 Error design FinalClass Class AuthUtil should be declared as final. 37

org/apache/hadoop/hbase/CellScanner.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.Cell. 25

org/apache/hadoop/hbase/CellUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 40
 Error sizes LineLength Line is longer than 100 characters (found 102). 194
 Error sizes LineLength Line is longer than 100 characters (found 101). 248
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 581

org/apache/hadoop/hbase/CompoundConfiguration.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'configs' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'c' must be private and have accessor methods. 80
 Error design VisibilityModifier Variable 'm' must be private and have accessor methods. 167
 Error design VisibilityModifier Variable 'm' must be private and have accessor methods. 228

org/apache/hadoop/hbase/CoordinatedStateManagerFactory.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 29

org/apache/hadoop/hbase/DaemonThreadFactory.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'group' must be private and have accessor methods. 28
 Error design VisibilityModifier Variable 'threadNumber' must be private and have accessor methods. 29
 Error design VisibilityModifier Variable 'namePrefix' must be private and have accessor methods. 30

org/apache/hadoop/hbase/DoNotRetryIOException.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.HBaseIOException. 23

org/apache/hadoop/hbase/HBaseConfiguration.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 47
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 60

org/apache/hadoop/hbase/HBaseInterfaceAudience.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 26

org/apache/hadoop/hbase/HConstants.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.nio.ByteBuffer. 22
 Error sizes LineLength Line is longer than 100 characters (found 101). 168
 Error sizes LineLength Line is longer than 100 characters (found 101). 198
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 429
 Error misc ArrayTypeStyle Array brackets at illegal position. 605
 Error design VisibilityModifier Variable 'HBASE_META_VERSIONS' must be private and have accessor methods. 750
 Error design VisibilityModifier Variable 'DEFAULT_HBASE_META_VERSIONS' must be private and have accessor methods. 755
 Error design VisibilityModifier Variable 'HBASE_META_BLOCK_SIZE' must be private and have accessor methods. 760
 Error design VisibilityModifier Variable 'DEFAULT_HBASE_META_BLOCK_SIZE' must be private and have accessor methods. 765
 Error sizes LineLength Line is longer than 100 characters (found 105). 794
 Error sizes LineLength Line is longer than 100 characters (found 103). 822
 Error whitespace MethodParamPad '(' should be on the previous line. 890
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 941
 Error sizes LineLength Line is longer than 100 characters (found 109). 1001
 Error sizes LineLength Line is longer than 100 characters (found 102). 1097

org/apache/hadoop/hbase/HRegionInfo.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 103
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 911

org/apache/hadoop/hbase/HRegionLocation.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 115). 107

org/apache/hadoop/hbase/HTableDescriptor.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 176
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 359
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 369
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 763
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 769
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1561
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1622
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1628
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1638

org/apache/hadoop/hbase/HealthChecker.java

Severity Category Rule Message Line
 Error coding MissingSwitchDefault switch without "default" clause. 108

org/apache/hadoop/hbase/JMXListener.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.CoprocessorEnvironment. 24
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - org.apache.hadoop.hbase.coprocessor.*. 25

org/apache/hadoop/hbase/KeyValue.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.io.EOFException. 26
 Error imports UnusedImports Unused import - org.apache.hadoop.io.IOUtils. 45
 Error design VisibilityModifier Variable 'bytes' must be private and have accessor methods. 272
 Error design VisibilityModifier Variable 'offset' must be private and have accessor methods. 273
 Error design VisibilityModifier Variable 'length' must be private and have accessor methods. 274
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1526
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1540
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1567
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1585
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1598
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1613
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 2503
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 2578
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 2695

org/apache/hadoop/hbase/KeyValueTestUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 32

org/apache/hadoop/hbase/KeyValueUtil.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.io.DataInput. 21
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 45
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 546

org/apache/hadoop/hbase/LocalHBaseCluster.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 105). 115
 Error sizes LineLength Line is longer than 100 characters (found 104). 460

org/apache/hadoop/hbase/MetaMigrationConvertingToPB.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 40

org/apache/hadoop/hbase/MetaMutationAnnotation.java

Severity Category Rule Message Line
 Error whitespace ParenPad '(' is followed by whitespace. 35

org/apache/hadoop/hbase/MetaTableAccessor.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 73
 Error blocks EmptyBlock Must have at least one statement. 246
 Error design VisibilityModifier Variable 'results' must be private and have accessor methods. 879
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 915

org/apache/hadoop/hbase/NamespaceDescriptor.java

Severity Category Rule Message Line
 Error design FinalClass Class NamespaceDescriptor should be declared as final. 40
 Error design FinalClass Class Builder should be declared as final. 164

org/apache/hadoop/hbase/PleaseHoldException.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.HBaseIOException. 23

org/apache/hadoop/hbase/RegionException.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.HBaseIOException. 23

org/apache/hadoop/hbase/RegionLoad.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'regionLoadPB' must be private and have accessor methods. 39

org/apache/hadoop/hbase/RegionLocations.java

Severity Category Rule Message Line
 Error whitespace ParenPad ')' is preceded with whitespace. 71

org/apache/hadoop/hbase/RegionTransition.java

Severity Category Rule Message Line
 Error design FinalClass Class RegionTransition should be declared as final. 38
 Error sizes LineLength Line is longer than 100 characters (found 101). 107

org/apache/hadoop/hbase/RemoteExceptionHandler.java

Severity Category Rule Message Line
 Error design FinalClass Class RemoteExceptionHandler should be declared as final. 32
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 86
 Error blocks EmptyBlock Must have at least one statement. 107
 Error blocks EmptyBlock Must have at least one statement. 109
 Error blocks EmptyBlock Must have at least one statement. 111
 Error blocks EmptyBlock Must have at least one statement. 113
 Error blocks EmptyBlock Must have at least one statement. 115

org/apache/hadoop/hbase/ScheduledChore.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.concurrent.ScheduledThreadPoolExecutor. 21

org/apache/hadoop/hbase/ServerLoad.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'serverLoad' must be private and have accessor methods. 86

org/apache/hadoop/hbase/ServerName.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 119). 45
 Error design FinalClass Class ServerName should be declared as final. 55

org/apache/hadoop/hbase/SplitLogCounters.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 29

org/apache/hadoop/hbase/TableExistsException.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.TableName. 23

org/apache/hadoop/hbase/TableInfoMissingException.java

Severity Category Rule Message Line
 Error whitespace ParenPad '(' is followed by whitespace. 37
 Error whitespace ParenPad ')' is preceded with whitespace. 37
 Error whitespace ParenPad '(' is followed by whitespace. 41
 Error whitespace ParenPad ')' is preceded with whitespace. 41
 Error whitespace ParenPad '(' is followed by whitespace. 45
 Error whitespace ParenPad ')' is preceded with whitespace. 45

org/apache/hadoop/hbase/TableName.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 109). 186
 Error sizes LineLength Line is longer than 100 characters (found 102). 191

org/apache/hadoop/hbase/TableNotDisabledException.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.TableName. 23

org/apache/hadoop/hbase/TableNotEnabledException.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.TableName. 23

org/apache/hadoop/hbase/TableNotFoundException.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.TableName. 23

org/apache/hadoop/hbase/TagRewriteCell.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 109
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 154
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 160
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 166
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 172

org/apache/hadoop/hbase/TagType.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 23

org/apache/hadoop/hbase/VersionAnnotation.java

Severity Category Rule Message Line
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.lang.annotation.*. 20

org/apache/hadoop/hbase/ZNodeClearer.java

Severity Category Rule Message Line
 Error design FinalClass Class ZNodeClearer should be declared as final. 47

org/apache/hadoop/hbase/backup/BackupDriver.java

Severity Category Rule Message Line
 Error whitespace ParenPad '(' is followed by whitespace. 108

org/apache/hadoop/hbase/backup/BackupInfo.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.backup.BackupType. 36
 Error whitespace ParenPad ')' is preceded with whitespace. 124
 Error sizes LineLength Line is longer than 100 characters (found 103). 168

org/apache/hadoop/hbase/backup/BackupRequest.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.backup.BackupType. 24

org/apache/hadoop/hbase/backup/BackupRestoreClientFactory.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 106). 51

org/apache/hadoop/hbase/backup/BackupRestoreServerFactory.java

Severity Category Rule Message Line
 Error coding EmptyStatement Empty statement. 61

org/apache/hadoop/hbase/backup/HBackupFileSystem.java

Severity Category Rule Message Line
 Error design FinalClass Class HBackupFileSystem should be declared as final. 40

org/apache/hadoop/hbase/backup/HFileArchiver.java

Severity Category Rule Message Line
 Error design FinalClass Class HFileArchiver should be declared as final. 53
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 509
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 549
 Error design VisibilityModifier Variable 'file' must be private and have accessor methods. 667

org/apache/hadoop/hbase/backup/RestoreDriver.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 102). 54
 Error sizes LineLength Line is longer than 100 characters (found 101). 68

org/apache/hadoop/hbase/backup/example/LongTermArchivingHFileCleaner.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'archiveTracker' must be private and have accessor methods. 48
 Error sizes LineLength Line is longer than 100 characters (found 101). 71

org/apache/hadoop/hbase/backup/example/TableHFileArchiveTracker.java

Severity Category Rule Message Line
 Error design FinalClass Class TableHFileArchiveTracker should be declared as final. 40

org/apache/hadoop/hbase/backup/impl/BackupCommands.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 112). 65
 Error design VisibilityModifier Variable 'cmdline' must be private and have accessor methods. 146
 Error sizes LineLength Line is longer than 100 characters (found 104). 195
 Error sizes LineLength Line is longer than 100 characters (found 103). 210
 Error design VisibilityModifier Variable 'cmdline' must be private and have accessor methods. 216
 Error design VisibilityModifier Variable 'cmdline' must be private and have accessor methods. 267
 Error design VisibilityModifier Variable 'cmdline' must be private and have accessor methods. 303
 Error design VisibilityModifier Variable 'cmdline' must be private and have accessor methods. 340
 Error design VisibilityModifier Variable 'cmdline' must be private and have accessor methods. 370
 Error blocks EmptyBlock Must have at least one statement. 386
 Error design VisibilityModifier Variable 'cmdline' must be private and have accessor methods. 393
 Error design VisibilityModifier Variable 'cmdline' must be private and have accessor methods. 429

org/apache/hadoop/hbase/backup/impl/BackupManifest.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.HBaseProtos. 48
 Error design VisibilityModifier Variable 'config' must be private and have accessor methods. 237

org/apache/hadoop/hbase/backup/impl/BackupRestoreConstants.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 103). 40

org/apache/hadoop/hbase/backup/impl/BackupSystemTable.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'backupId' must be private and have accessor methods. 73
 Error design VisibilityModifier Variable 'walFile' must be private and have accessor methods. 74
 Error design VisibilityModifier Variable 'backupRoot' must be private and have accessor methods. 75
 Error coding EmptyStatement Empty statement. 285
 Error whitespace MethodParamPad '(' is preceded with whitespace. 658
 Error sizes LineLength Line is longer than 100 characters (found 105). 700

org/apache/hadoop/hbase/backup/impl/BackupSystemTableHelper.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.EnvironmentEdgeManager. 44
 Error whitespace ParenPad ')' is preceded with whitespace. 272
 Error whitespace ParenPad '(' is followed by whitespace. 541

org/apache/hadoop/hbase/backup/mapreduce/MapReduceBackupCopyService.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.fs.LocatedFileStatus. 31
 Error imports UnusedImports Unused import - org.apache.hadoop.fs.RemoteIterator. 33
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil. 41
 Error imports UnusedImports Unused import - org.apache.hadoop.mapreduce.Mapper. 46
 Error imports UnusedImports Unused import - org.apache.hadoop.util.ClassUtil. 50
 Error imports UnusedImports Unused import - org.apache.zookeeper.KeeperException.NoNodeException. 51

org/apache/hadoop/hbase/backup/master/FullTableBackupProcedure.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.NotServingRegionException. 38
 Error sizes LineLength Line is longer than 100 characters (found 102). 75
 Error sizes LineLength Line is longer than 100 characters (found 106). 78
 Error design VisibilityModifier Variable 'newTimestamps' must be private and have accessor methods. 86
 Error sizes LineLength Line is longer than 100 characters (found 106). 602
 Error whitespace ParenPad '(' is followed by whitespace. 638

org/apache/hadoop/hbase/backup/master/IncrementalTableBackupProcedure.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'newTimestamps' must be private and have accessor methods. 82
 Error sizes LineLength Line is longer than 100 characters (found 111). 471
 Error whitespace MethodParamPad '(' is preceded with whitespace. 489

org/apache/hadoop/hbase/backup/master/LogRollMasterProcedureManager.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 102). 50

org/apache/hadoop/hbase/backup/regionserver/LogRollBackupSubprocedure.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 103). 84

org/apache/hadoop/hbase/backup/regionserver/LogRollRegionServerProcedureManager.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.HRegionServer. 37

org/apache/hadoop/hbase/backup/util/BackupServerUtil.java

Severity Category Rule Message Line
 Error coding EmptyStatement Empty statement. 439

org/apache/hadoop/hbase/backup/util/RestoreServerUtil.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.HRegionFileSystem. 50
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.HStore. 51
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 69
 Error design VisibilityModifier Variable 'backupRootPath' must be private and have accessor methods. 71
 Error design VisibilityModifier Variable 'backupId' must be private and have accessor methods. 73
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 75

org/apache/hadoop/hbase/classification/InterfaceAudience.java

Severity Category Rule Message Line
 Error design FinalClass Class InterfaceAudience should be declared as final. 45

org/apache/hadoop/hbase/classification/tools/ExcludePrivateAnnotationsStandardDoclet.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 33

org/apache/hadoop/hbase/classification/tools/IncludePublicAnnotationsStandardDoclet.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 38

org/apache/hadoop/hbase/classification/tools/RootDocProcessor.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 50
 Error design VisibilityModifier Variable 'stability' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'treatUnannotatedClassesAsPrivate' must be private and have accessor methods. 53

org/apache/hadoop/hbase/classification/tools/StabilityOptions.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 25

org/apache/hadoop/hbase/client/AbstractClientScanner.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'scanMetrics' must be private and have accessor methods. 32
 Error design VisibilityModifier Variable 'next' must be private and have accessor methods. 84

org/apache/hadoop/hbase/client/Admin.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.backup.BackupRequest. 40
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.backup.BackupType. 41

org/apache/hadoop/hbase/client/Append.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 144
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 160

org/apache/hadoop/hbase/client/AsyncProcess.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'result' must be private and have accessor methods. 138
 Error design VisibilityModifier Variable 'callCount' must be private and have accessor methods. 161
 Error design VisibilityModifier Variable 'replicaErrors' must be private and have accessor methods. 164
 Error design VisibilityModifier Variable 'id' must be private and have accessor methods. 174
 Error design VisibilityModifier Variable 'connection' must be private and have accessor methods. 176
 Error design VisibilityModifier Variable 'rpcCallerFactory' must be private and have accessor methods. 177
 Error design VisibilityModifier Variable 'rpcFactory' must be private and have accessor methods. 178
 Error design VisibilityModifier Variable 'globalErrors' must be private and have accessor methods. 179
 Error design VisibilityModifier Variable 'pool' must be private and have accessor methods. 180
 Error design VisibilityModifier Variable 'tasksInProgress' must be private and have accessor methods. 182
 Error design VisibilityModifier Variable 'taskCounterPerRegion' must be private and have accessor methods. 183
 Error design VisibilityModifier Variable 'taskCounterPerServer' must be private and have accessor methods. 185
 Error design VisibilityModifier Variable 'maxTotalConcurrentTasks' must be private and have accessor methods. 194
 Error design VisibilityModifier Variable 'maxConcurrentTasksPerRegion' must be private and have accessor methods. 202
 Error design VisibilityModifier Variable 'maxConcurrentTasksPerServer' must be private and have accessor methods. 207
 Error design VisibilityModifier Variable 'pause' must be private and have accessor methods. 208
 Error design VisibilityModifier Variable 'numTries' must be private and have accessor methods. 209
 Error design VisibilityModifier Variable 'serverTrackerTimeout' must be private and have accessor methods. 210
 Error design VisibilityModifier Variable 'timeout' must be private and have accessor methods. 211
 Error design VisibilityModifier Variable 'primaryCallTimeoutMicroseconds' must be private and have accessor methods. 212
 Error sizes LineLength Line is longer than 100 characters (found 101). 254
 Error sizes LineLength Line is longer than 100 characters (found 136). 325
 Error sizes LineLength Line is longer than 100 characters (found 131). 528
 Error sizes LineLength Line is longer than 100 characters (found 140). 884
 Error sizes LineLength Line is longer than 100 characters (found 124). 932
 Error coding InnerAssignment Inner assignments should be avoided. 1404
 Error coding InnerAssignment Inner assignments should be avoided. 1444
 Error coding InnerAssignment Inner assignments should be avoided. 1514
 Error sizes LineLength Line is longer than 100 characters (found 102). 1817

org/apache/hadoop/hbase/client/BufferedMutatorImpl.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'connection' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'currentWriteBufferSize' must be private and have accessor methods. 58
 Error design VisibilityModifier Variable 'ap' must be private and have accessor methods. 61

org/apache/hadoop/hbase/client/ClientIdGenerator.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 34

org/apache/hadoop/hbase/client/ClientScanner.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'MAX_BYTE_ARRAY' must be private and have accessor methods. 63
 Error design VisibilityModifier Variable 'scan' must be private and have accessor methods. 64
 Error design VisibilityModifier Variable 'closed' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'currentRegion' must be private and have accessor methods. 68
 Error design VisibilityModifier Variable 'callable' must be private and have accessor methods. 69
 Error design VisibilityModifier Variable 'cache' must be private and have accessor methods. 70
 Error design VisibilityModifier Variable 'partialResults' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'partialResultsRow' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'lastCellLoadedToCache' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'caching' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'lastNext' must be private and have accessor methods. 88
 Error design VisibilityModifier Variable 'lastResult' must be private and have accessor methods. 90
 Error design VisibilityModifier Variable 'maxScannerResultSize' must be private and have accessor methods. 91
 Error design VisibilityModifier Variable 'scannerTimeout' must be private and have accessor methods. 94
 Error design VisibilityModifier Variable 'scanMetricsPublished' must be private and have accessor methods. 95
 Error design VisibilityModifier Variable 'caller' must be private and have accessor methods. 96
 Error design VisibilityModifier Variable 'rpcControllerFactory' must be private and have accessor methods. 97
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 98
 Error design VisibilityModifier Variable 'primaryOperationTimeout' must be private and have accessor methods. 104
 Error design VisibilityModifier Variable 'pool' must be private and have accessor methods. 106
 Error sizes MethodLength Method length is 188 lines (max allowed is 150). 391
 Error whitespace ParenPad ')' is preceded with whitespace. 485
 Error whitespace ParenPad ')' is preceded with whitespace. 535
 Error blocks EmptyBlock Must have at least one statement. 767

org/apache/hadoop/hbase/client/ClientSideRegionScanner.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'scanner' must be private and have accessor methods. 46
 Error design VisibilityModifier Variable 'values' must be private and have accessor methods. 47

org/apache/hadoop/hbase/client/ClientSmallReversedScanner.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.ClientSmallScanner.SmallScannerCallable. 32

org/apache/hadoop/hbase/client/ClusterConnection.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 109). 202
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 258

org/apache/hadoop/hbase/client/ClusterStatusListener.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'deadServerHandler' must be private and have accessor methods. 66

org/apache/hadoop/hbase/client/ConnectionAdapter.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 24 - org.apache.hadoop.hbase.classification.InterfaceAudience. 33

org/apache/hadoop/hbase/client/ConnectionManager.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.RegionTooBusyException. 58
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.exceptions.RegionOpeningException. 73
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - org.apache.hadoop.hbase.protobuf.generated.*. 83
 Error design FinalClass Class ConnectionManager should be declared as final. 207
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 291
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 421
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 428
 Error annotation MissingDeprecated Missing a Javadoc comment. 441
 Error annotation MissingDeprecated Missing a Javadoc comment. 453
 Error annotation MissingDeprecated Missing a Javadoc comment. 464
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 488
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 500
 Error design VisibilityModifier Variable 'rpcTimeout' must be private and have accessor methods. 563
 Error design VisibilityModifier Variable 'clusterStatusListener' must be private and have accessor methods. 573
 Error design VisibilityModifier Variable 'registry' must be private and have accessor methods. 622
 Error sizes LineLength Line is longer than 100 characters (found 105). 750
 Error design VisibilityModifier Variable 'clusterId' must be private and have accessor methods. 899
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 939
 Error whitespace MethodParamPad '(' is preceded with whitespace. 1084
 Error design VisibilityModifier Variable 'connection' must be private and have accessor methods. 1441
 Error design VisibilityModifier Variable 'stub' must be private and have accessor methods. 1442
 Error design VisibilityModifier Variable 'userCount' must be private and have accessor methods. 1443
 Error whitespace MethodParamPad '(' is preceded with whitespace. 1445
 Error whitespace ParenPad ')' is preceded with whitespace. 1695
 Error design VisibilityModifier Variable 'masterServiceState' must be private and have accessor methods. 1713
 Error sizes MethodLength Method length is 407 lines (max allowed is 150). 1724
 Error design VisibilityModifier Variable 'mss' must be private and have accessor methods. 1744
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 2119
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 2276
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 2292
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 2326
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 2370
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 2375
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 2381
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 2387
 Error coding NoFinalizer Avoid using finalizer method. 2498
 Error misc ArrayTypeStyle Array brackets at illegal position. 2531
 Error design VisibilityModifier Variable 'retries' must be private and have accessor methods. 2736

org/apache/hadoop/hbase/client/ConnectionUtils.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.RegionLocations. 28
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 40

org/apache/hadoop/hbase/client/DelegatingRetryingCallable.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'delegate' must be private and have accessor methods. 27

org/apache/hadoop/hbase/client/Delete.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 435
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 451

org/apache/hadoop/hbase/client/FailureInfo.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'numConsecutiveFailures' must be private and have accessor methods. 35
 Error design VisibilityModifier Variable 'timeOfFirstFailureMilliSec' must be private and have accessor methods. 38
 Error design VisibilityModifier Variable 'timeOfLatestAttemptMilliSec' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'exclusivelyRetringInspiteOfFastFail' must be private and have accessor methods. 45

org/apache/hadoop/hbase/client/HBaseAdmin.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.net.SocketTimeoutException. 24
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.RegionException. 57
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.TableNotEnabledException. 63
 Error misc ArrayTypeStyle Array brackets at illegal position. 473
 Error misc ArrayTypeStyle Array brackets at illegal position. 490
 Error design VisibilityModifier Variable 'backupId' must be private and have accessor methods. 2767
 Error coding MissingSwitchDefault switch without "default" clause. 3429
 Error sizes LineLength Line is longer than 100 characters (found 101). 3613
 Error sizes LineLength Line is longer than 100 characters (found 106). 3888
 Error sizes LineLength Line is longer than 100 characters (found 106). 4210

org/apache/hadoop/hbase/client/HBaseBackupAdmin.java

Severity Category Rule Message Line
 Error whitespace ParenPad '(' is followed by whitespace. 160
 Error whitespace ParenPad '(' is followed by whitespace. 177
 Error sizes LineLength Line is longer than 100 characters (found 102). 224

org/apache/hadoop/hbase/client/HConnectable.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 43

org/apache/hadoop/hbase/client/HConnection.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 202
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 212
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 222
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 241
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 276
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 280
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 298
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 317
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 340
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 344
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 362
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 386
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 404
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 461
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 485
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 501
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 551

org/apache/hadoop/hbase/client/HConnectionManager.java

Severity Category Rule Message Line
 Error design FinalClass Class HConnectionManager should be declared as final. 85
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 90
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 94
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 114
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 142
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 168
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 194
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 221
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 227
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 233
 Error annotation MissingDeprecated Missing a Javadoc comment. 245
 Error annotation MissingDeprecated Missing a Javadoc comment. 257
 Error annotation MissingDeprecated Missing a Javadoc comment. 268

org/apache/hadoop/hbase/client/HTable.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.TableNotFoundException. 51
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest. 69
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse. 70
 Error design VisibilityModifier Variable 'connection' must be private and have accessor methods. 118
 Error design VisibilityModifier Variable 'mutator' must be private and have accessor methods. 122
 Error design VisibilityModifier Variable 'scannerCaching' must be private and have accessor methods. 125
 Error design VisibilityModifier Variable 'scannerMaxResultSize' must be private and have accessor methods. 126
 Error design VisibilityModifier Variable 'multiAp' must be private and have accessor methods. 136
 Error coding InnerAssignment Inner assignments should be avoided. 180
 Error sizes LineLength Line is longer than 100 characters (found 117). 624
 Error sizes LineLength Line is longer than 100 characters (found 102). 945
 Error sizes LineLength Line is longer than 100 characters (found 109). 1000
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1413
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1524
 Error sizes LineLength Line is longer than 100 characters (found 103). 1754

org/apache/hadoop/hbase/client/HTableMultiplexer.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 186
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 228
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 236
 Error sizes LineLength Line is longer than 100 characters (found 101). 256
 Error design VisibilityModifier Variable 'regionInfo' must be private and have accessor methods. 381
 Error design VisibilityModifier Variable 'put' must be private and have accessor methods. 382
 Error design VisibilityModifier Variable 'retryCount' must be private and have accessor methods. 383
 Error misc UpperEll Should use uppercase 'L'. 422

org/apache/hadoop/hbase/client/HTablePool.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Missing a Javadoc comment. 232
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 234
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 394
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 413
 Error sizes LineLength Line is longer than 100 characters (found 104). 584
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 587
 Error sizes LineLength Line is longer than 100 characters (found 105). 641

org/apache/hadoop/hbase/client/HTableUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 36
 Error sizes LineLength Line is longer than 100 characters (found 118). 43
 Error sizes LineLength Line is longer than 100 characters (found 132). 44
 Error sizes LineLength Line is longer than 100 characters (found 112). 46
 Error sizes LineLength Line is longer than 100 characters (found 132). 48
 Error sizes LineLength Line is longer than 100 characters (found 114). 49
 Error sizes LineLength Line is longer than 100 characters (found 126). 51
 Error sizes LineLength Line is longer than 100 characters (found 123). 53
 Error sizes LineLength Line is longer than 100 characters (found 108). 56
 Error whitespace ParenPad '(' is followed by whitespace. 67
 Error whitespace ParenPad ')' is preceded with whitespace. 67
 Error sizes LineLength Line is longer than 100 characters (found 134). 73
 Error sizes LineLength Line is longer than 100 characters (found 113). 75
 Error sizes LineLength Line is longer than 100 characters (found 132). 78
 Error sizes LineLength Line is longer than 100 characters (found 114). 79
 Error sizes LineLength Line is longer than 100 characters (found 126). 81
 Error sizes LineLength Line is longer than 100 characters (found 123). 83
 Error sizes LineLength Line is longer than 100 characters (found 114). 86
 Error whitespace ParenPad '(' is followed by whitespace. 97
 Error whitespace ParenPad ')' is preceded with whitespace. 97
 Error sizes LineLength Line is longer than 100 characters (found 112). 105
 Error whitespace ParenPad '(' is followed by whitespace. 109
 Error whitespace ParenPad ')' is preceded with whitespace. 109
 Error whitespace ParenPad '(' is followed by whitespace. 111
 Error whitespace ParenPad '(' is followed by whitespace. 114
 Error sizes LineLength Line is longer than 100 characters (found 112). 121
 Error whitespace ParenPad '(' is followed by whitespace. 125
 Error whitespace ParenPad ')' is preceded with whitespace. 125
 Error whitespace ParenPad '(' is followed by whitespace. 127
 Error whitespace ParenPad '(' is followed by whitespace. 130

org/apache/hadoop/hbase/client/HTableWrapper.java

Severity Category Rule Message Line
 Error design FinalClass Class HTableWrapper should be declared as final. 56
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 113
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 136
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 252
 Error sizes LineLength Line is longer than 100 characters (found 102). 268
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 271

org/apache/hadoop/hbase/client/Increment.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 311
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 327

org/apache/hadoop/hbase/client/MasterCallable.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'connection' must be private and have accessor methods. 29
 Error design VisibilityModifier Variable 'master' must be private and have accessor methods. 30

org/apache/hadoop/hbase/client/MetaCache.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 106). 261
 Error sizes LineLength Line is longer than 100 characters (found 118). 394

org/apache/hadoop/hbase/client/MetaScanner.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 57

org/apache/hadoop/hbase/client/MultiAction.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'actions' must be private and have accessor methods. 41

org/apache/hadoop/hbase/client/MultiServerCallable.java

Severity Category Rule Message Line
 Error whitespace ParenPad ')' is preceded with whitespace. 103

org/apache/hadoop/hbase/client/Mutation.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'row' must be private and have accessor methods. 88
 Error design VisibilityModifier Variable 'ts' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'durability' must be private and have accessor methods. 90
 Error design VisibilityModifier Variable 'familyMap' must be private and have accessor methods. 93
 Error whitespace ParenPad ')' is preceded with whitespace. 199

org/apache/hadoop/hbase/client/PreemptiveFastFailInterceptor.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.exceptions.ClientExceptionsUtil. 40
 Error design VisibilityModifier Variable 'fastFailThresholdMilliSec' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'repeatedFailuresMap' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'failureMapCleanupIntervalMilliSec' must be private and have accessor methods. 92
 Error design VisibilityModifier Variable 'lastFailureMapCleanupTimeMilliSec' must be private and have accessor methods. 94

org/apache/hadoop/hbase/client/Put.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 476
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 492

org/apache/hadoop/hbase/client/Query.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'filter' must be private and have accessor methods. 38
 Error design VisibilityModifier Variable 'targetReplicaId' must be private and have accessor methods. 39
 Error design VisibilityModifier Variable 'consistency' must be private and have accessor methods. 40

org/apache/hadoop/hbase/client/QuotaStatusCalls.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 36
 Error sizes LineLength Line is longer than 100 characters (found 110). 40
 Error sizes LineLength Line is longer than 100 characters (found 110). 69
 Error sizes LineLength Line is longer than 100 characters (found 104). 101

org/apache/hadoop/hbase/client/RegionAdminServiceCallable.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'connection' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'rpcControllerFactory' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'stub' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'location' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'tableName' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'row' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'replicaId' must be private and have accessor methods. 55

org/apache/hadoop/hbase/client/RegionReplicaUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 31

org/apache/hadoop/hbase/client/RegionServerCallable.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'connection' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'tableName' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'row' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'location' must be private and have accessor methods. 54

org/apache/hadoop/hbase/client/RegistryFactory.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 27

org/apache/hadoop/hbase/client/Result.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HConstants. 37
 Error sizes LineLength Line is longer than 100 characters (found 101). 62
 Error sizes LineLength Line is longer than 100 characters (found 108). 99
 Error sizes LineLength Line is longer than 100 characters (found 121). 117
 Error sizes LineLength Line is longer than 100 characters (found 102). 211
 Error whitespace ParenPad ')' is preceded with whitespace. 321
 Error sizes LineLength Line is longer than 100 characters (found 115). 688
 Error whitespace MethodParamPad '(' should be on the previous line. 695

org/apache/hadoop/hbase/client/RetriesExhaustedWithDetailsException.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'exceptions' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'actions' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'hostnameAndPort' must be private and have accessor methods. 52
 Error whitespace ParenPad '(' is followed by whitespace. 91

org/apache/hadoop/hbase/client/ReversedScannerCallable.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.classification.InterfaceStability. 27
 Error imports RedundantImport Duplicate import to line 26 - org.apache.hadoop.hbase.classification.InterfaceAudience. 33
 Error design VisibilityModifier Variable 'locateStartRow' must be private and have accessor methods. 49
 Error sizes LineLength Line is longer than 100 characters (found 103). 77
 Error sizes LineLength Line is longer than 100 characters (found 129). 84

org/apache/hadoop/hbase/client/RpcRetryingCallerFactory.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 33

org/apache/hadoop/hbase/client/RpcRetryingCallerWithReadReplicas.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.concurrent.Executor. 50
 Error imports UnusedImports Unused import - java.util.concurrent.RunnableFuture. 53
 Error imports UnusedImports Unused import - java.util.concurrent.TimeoutException. 55
 Error design VisibilityModifier Variable 'pool' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'cConnection' must be private and have accessor methods. 68
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 69
 Error design VisibilityModifier Variable 'get' must be private and have accessor methods. 70
 Error design VisibilityModifier Variable 'tableName' must be private and have accessor methods. 71
 Error design VisibilityModifier Variable 'timeBeforeReplicas' must be private and have accessor methods. 72
 Error design VisibilityModifier Variable 'id' must be private and have accessor methods. 102
 Error sizes LineLength Line is longer than 100 characters (found 117). 214
 Error sizes LineLength Line is longer than 100 characters (found 101). 243

org/apache/hadoop/hbase/client/Scan.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 133

org/apache/hadoop/hbase/client/ScannerCallable.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'scannerId' must be private and have accessor methods. 70
 Error design VisibilityModifier Variable 'instantiated' must be private and have accessor methods. 71
 Error design VisibilityModifier Variable 'closed' must be private and have accessor methods. 72
 Error design VisibilityModifier Variable 'renew' must be private and have accessor methods. 73
 Error design VisibilityModifier Variable 'cConnection' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'scanMetrics' must be private and have accessor methods. 77
 Error design VisibilityModifier Variable 'id' must be private and have accessor methods. 81
 Error design VisibilityModifier Variable 'serverHasMoreResultsContext' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'serverHasMoreResults' must be private and have accessor methods. 83
 Error design VisibilityModifier Variable 'heartbeatMessage' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'isRegionServerRemote' must be private and have accessor methods. 99
 Error design VisibilityModifier Variable 'controllerFactory' must be private and have accessor methods. 101
 Error design VisibilityModifier Variable 'controller' must be private and have accessor methods. 102
 Error whitespace MethodParamPad '(' is preceded with whitespace. 113
 Error whitespace MethodParamPad '(' is preceded with whitespace. 125
 Error sizes LineLength Line is longer than 100 characters (found 101). 216

org/apache/hadoop/hbase/client/ScannerCallableWithReplicas.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.concurrent.TimeoutException. 33
 Error design VisibilityModifier Variable 'currentScannerCallable' must be private and have accessor methods. 64
 Error design VisibilityModifier Variable 'replicaSwitched' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'cConnection' must be private and have accessor methods. 66
 Error design VisibilityModifier Variable 'pool' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'timeBeforeReplicas' must be private and have accessor methods. 68
 Error design VisibilityModifier Variable 'callable' must be private and have accessor methods. 371
 Error design VisibilityModifier Variable 'caller' must be private and have accessor methods. 372

org/apache/hadoop/hbase/client/ServerStatisticTracker.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.Map. 28
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 53

org/apache/hadoop/hbase/client/Table.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 119). 501
 Error sizes LineLength Line is longer than 100 characters (found 101). 513

org/apache/hadoop/hbase/client/UnmodifyableHTableDescriptor.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 125). 126

org/apache/hadoop/hbase/client/ZooKeeperRegistry.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'hci' must be private and have accessor methods. 43

org/apache/hadoop/hbase/client/coprocessor/AggregationClient.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 35 - org.apache.hadoop.hbase.classification.InterfaceAudience. 40
 Error design VisibilityModifier Variable 'max' must be private and have accessor methods. 143
 Error design VisibilityModifier Variable 'sumVal' must be private and have accessor methods. 372
 Error design VisibilityModifier Variable 'sum' must be private and have accessor methods. 437
 Error design VisibilityModifier Variable 'rowCount' must be private and have accessor methods. 438
 Error misc UpperEll Should use uppercase 'L'. 438
 Error design VisibilityModifier Variable 'rowCountVal' must be private and have accessor methods. 534
 Error misc UpperEll Should use uppercase 'L'. 534
 Error design VisibilityModifier Variable 'sumVal' must be private and have accessor methods. 535
 Error design VisibilityModifier Variable 'sumSqVal' must be private and have accessor methods. 535
 Error design VisibilityModifier Variable 'sumVal' must be private and have accessor methods. 652
 Error design VisibilityModifier Variable 'sumWeights' must be private and have accessor methods. 652
 Error coding InnerAssignment Inner assignments should be avoided. 805

org/apache/hadoop/hbase/client/coprocessor/Batch.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 147). 39
 Error sizes LineLength Line is longer than 100 characters (found 144). 45
 Error sizes LineLength Line is longer than 100 characters (found 147). 62
 Error sizes LineLength Line is longer than 100 characters (found 144). 68

org/apache/hadoop/hbase/client/coprocessor/LongColumnInterpreter.java

Severity Category Rule Message Line
 Error misc UpperEll Should use uppercase 'L'. 74

org/apache/hadoop/hbase/client/coprocessor/RowProcessorClient.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 35

org/apache/hadoop/hbase/client/coprocessor/SecureBulkLoadClient.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 23 - java.io.IOException. 41
 Error imports RedundantImport Duplicate import to line 24 - java.util.ArrayList. 42
 Error imports RedundantImport Duplicate import to line 25 - java.util.List. 43

org/apache/hadoop/hbase/client/coprocessor/package-info.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 146). 54
 Error sizes LineLength Line is longer than 100 characters (found 200). 55
 Error sizes LineLength Line is longer than 100 characters (found 144). 74
 Error sizes LineLength Line is longer than 100 characters (found 206). 75
 Error sizes LineLength Line is longer than 100 characters (found 111). 95
 Error sizes LineLength Line is longer than 100 characters (found 105). 96
 Error sizes LineLength Line is longer than 100 characters (found 129). 138
 Error sizes LineLength Line is longer than 100 characters (found 129). 143
 Error sizes LineLength Line is longer than 100 characters (found 132). 149
 Error sizes LineLength Line is longer than 100 characters (found 169). 190

org/apache/hadoop/hbase/client/metrics/ScanMetrics.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'countOfRPCcalls' must be private and have accessor methods. 59
 Error design VisibilityModifier Variable 'countOfRemoteRPCcalls' must be private and have accessor methods. 64
 Error design VisibilityModifier Variable 'sumOfMillisSecBetweenNexts' must be private and have accessor methods. 69
 Error design VisibilityModifier Variable 'countOfNSRE' must be private and have accessor methods. 74
 Error design VisibilityModifier Variable 'countOfBytesInResults' must be private and have accessor methods. 79
 Error design VisibilityModifier Variable 'countOfBytesInRemoteResults' must be private and have accessor methods. 84
 Error design VisibilityModifier Variable 'countOfRegions' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'countOfRPCRetries' must be private and have accessor methods. 94
 Error design VisibilityModifier Variable 'countOfRemoteRPCRetries' must be private and have accessor methods. 99

org/apache/hadoop/hbase/client/replication/ReplicationAdmin.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.TreeMap. 32
 Error imports RedundantImport Duplicate import to line 37 - org.apache.hadoop.hbase.classification.InterfaceAudience. 46
 Error imports RedundantImport Duplicate import to line 38 - org.apache.hadoop.hbase.classification.InterfaceStability. 47
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.HBaseAdmin. 49
 Error imports RedundantImport Duplicate import to line 65 - com.google.common.annotations.VisibleForTesting. 68
 Error imports RedundantImport Duplicate import to line 66 - com.google.common.collect.Lists. 69
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 191
 Error sizes LineLength Line is longer than 100 characters (found 101). 455

org/apache/hadoop/hbase/codec/BaseDecoder.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'in' must be private and have accessor methods. 39

org/apache/hadoop/hbase/codec/BaseEncoder.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'out' must be private and have accessor methods. 32
 Error design VisibilityModifier Variable 'flushed' must be private and have accessor methods. 34

org/apache/hadoop/hbase/codec/KeyValueCodec.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.KeyValue. 27

org/apache/hadoop/hbase/codec/KeyValueCodecWithTags.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.KeyValue. 27

org/apache/hadoop/hbase/codec/prefixtree/PrefixTreeBlockMeta.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'arrayOffset' must be private and have accessor methods. 60
 Error design VisibilityModifier Variable 'bufferOffset' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'version' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'numMetaBytes' must be private and have accessor methods. 68
 Error design VisibilityModifier Variable 'numKeyValueBytes' must be private and have accessor methods. 69
 Error design VisibilityModifier Variable 'includesMvccVersion' must be private and have accessor methods. 70
 Error design VisibilityModifier Variable 'numRowBytes' must be private and have accessor methods. 73
 Error design VisibilityModifier Variable 'numFamilyBytes' must be private and have accessor methods. 74
 Error design VisibilityModifier Variable 'numQualifierBytes' must be private and have accessor methods. 75
 Error design VisibilityModifier Variable 'numTimestampBytes' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'numMvccVersionBytes' must be private and have accessor methods. 77
 Error design VisibilityModifier Variable 'numValueBytes' must be private and have accessor methods. 78
 Error design VisibilityModifier Variable 'numTagsBytes' must be private and have accessor methods. 79
 Error design VisibilityModifier Variable 'nextNodeOffsetWidth' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'familyOffsetWidth' must be private and have accessor methods. 83
 Error design VisibilityModifier Variable 'qualifierOffsetWidth' must be private and have accessor methods. 84
 Error design VisibilityModifier Variable 'timestampIndexWidth' must be private and have accessor methods. 85
 Error design VisibilityModifier Variable 'mvccVersionIndexWidth' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'valueOffsetWidth' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'valueLengthWidth' must be private and have accessor methods. 88
 Error design VisibilityModifier Variable 'tagsOffsetWidth' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'rowTreeDepth' must be private and have accessor methods. 92
 Error design VisibilityModifier Variable 'maxRowLength' must be private and have accessor methods. 93
 Error design VisibilityModifier Variable 'maxQualifierLength' must be private and have accessor methods. 94
 Error design VisibilityModifier Variable 'maxTagsLength' must be private and have accessor methods. 95
 Error design VisibilityModifier Variable 'minTimestamp' must be private and have accessor methods. 98
 Error design VisibilityModifier Variable 'timestampDeltaWidth' must be private and have accessor methods. 99
 Error design VisibilityModifier Variable 'minMvccVersion' must be private and have accessor methods. 100
 Error design VisibilityModifier Variable 'mvccVersionDeltaWidth' must be private and have accessor methods. 101
 Error design VisibilityModifier Variable 'allSameType' must be private and have accessor methods. 103
 Error design VisibilityModifier Variable 'allTypes' must be private and have accessor methods. 104
 Error design VisibilityModifier Variable 'numUniqueRows' must be private and have accessor methods. 106
 Error design VisibilityModifier Variable 'numUniqueFamilies' must be private and have accessor methods. 107
 Error design VisibilityModifier Variable 'numUniqueQualifiers' must be private and have accessor methods. 108
 Error design VisibilityModifier Variable 'numUniqueTags' must be private and have accessor methods. 109

org/apache/hadoop/hbase/codec/prefixtree/PrefixTreeCodec.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 107). 57
 Error sizes LineLength Line is longer than 100 characters (found 101). 153
 Error sizes LineLength Line is longer than 100 characters (found 104). 157
 Error design VisibilityModifier Variable 'builder' must be private and have accessor methods. 178

org/apache/hadoop/hbase/codec/prefixtree/PrefixTreeSeeker.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'block' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'includeMvccVersion' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'ptSearcher' must be private and have accessor methods. 52
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 374
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 415
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 421
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 427
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 433

org/apache/hadoop/hbase/codec/prefixtree/decode/ArraySearcherPool.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'pool' must be private and have accessor methods. 44

org/apache/hadoop/hbase/codec/prefixtree/decode/DecoderFactory.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 30

org/apache/hadoop/hbase/codec/prefixtree/decode/PrefixTreeArrayReversibleScanner.java

Severity Category Rule Message Line
 Error coding EqualsHashCode Definition of 'equals()' without corresponding definition of 'hashCode()'. 43

org/apache/hadoop/hbase/codec/prefixtree/decode/PrefixTreeArrayScanner.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'blockMeta' must be private and have accessor methods. 46
 Error design VisibilityModifier Variable 'beforeFirst' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'afterLast' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'rowNodes' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'rowNodeStackIndex' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'currentRowNode' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'familyReader' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'qualifierReader' must be private and have accessor methods. 56
 Error design VisibilityModifier Variable 'tagsReader' must be private and have accessor methods. 57
 Error design VisibilityModifier Variable 'timestampDecoder' must be private and have accessor methods. 58
 Error design VisibilityModifier Variable 'mvccVersionDecoder' must be private and have accessor methods. 59
 Error design VisibilityModifier Variable 'nubCellsRemain' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'currentCellIndex' must be private and have accessor methods. 62

org/apache/hadoop/hbase/codec/prefixtree/decode/PrefixTreeArraySearcher.java

Severity Category Rule Message Line
 Error coding EqualsHashCode Definition of 'equals()' without corresponding definition of 'hashCode()'. 199

org/apache/hadoop/hbase/codec/prefixtree/decode/PrefixTreeCell.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'block' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'includeMvccVersion' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'rowBuffer' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'rowLength' must be private and have accessor methods. 56
 Error design VisibilityModifier Variable 'familyBuffer' must be private and have accessor methods. 58
 Error design VisibilityModifier Variable 'familyOffset' must be private and have accessor methods. 59
 Error design VisibilityModifier Variable 'familyLength' must be private and have accessor methods. 60
 Error design VisibilityModifier Variable 'qualifierBuffer' must be private and have accessor methods. 62
 Error design VisibilityModifier Variable 'qualifierOffset' must be private and have accessor methods. 63
 Error design VisibilityModifier Variable 'qualifierLength' must be private and have accessor methods. 64
 Error design VisibilityModifier Variable 'timestamp' must be private and have accessor methods. 66
 Error design VisibilityModifier Variable 'mvccVersion' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'type' must be private and have accessor methods. 69
 Error design VisibilityModifier Variable 'absoluteValueOffset' must be private and have accessor methods. 71
 Error design VisibilityModifier Variable 'valueLength' must be private and have accessor methods. 72
 Error design VisibilityModifier Variable 'tagsBuffer' must be private and have accessor methods. 74
 Error design VisibilityModifier Variable 'tagsOffset' must be private and have accessor methods. 75
 Error design VisibilityModifier Variable 'tagsLength' must be private and have accessor methods. 76

org/apache/hadoop/hbase/codec/prefixtree/decode/column/ColumnNodeReader.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'blockMeta' must be private and have accessor methods. 32
 Error design VisibilityModifier Variable 'block' must be private and have accessor methods. 33
 Error design VisibilityModifier Variable 'nodeType' must be private and have accessor methods. 34
 Error design VisibilityModifier Variable 'columnBuffer' must be private and have accessor methods. 35
 Error design VisibilityModifier Variable 'offsetIntoBlock' must be private and have accessor methods. 37
 Error design VisibilityModifier Variable 'tokenOffsetIntoBlock' must be private and have accessor methods. 39
 Error design VisibilityModifier Variable 'tokenLength' must be private and have accessor methods. 40
 Error design VisibilityModifier Variable 'parentStartPosition' must be private and have accessor methods. 41

org/apache/hadoop/hbase/codec/prefixtree/decode/column/ColumnReader.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'blockMeta' must be private and have accessor methods. 34
 Error design VisibilityModifier Variable 'columnBuffer' must be private and have accessor methods. 36
 Error design VisibilityModifier Variable 'columnOffset' must be private and have accessor methods. 37
 Error design VisibilityModifier Variable 'columnLength' must be private and have accessor methods. 38
 Error design VisibilityModifier Variable 'nodeType' must be private and have accessor methods. 39
 Error design VisibilityModifier Variable 'columnNodeReader' must be private and have accessor methods. 41

org/apache/hadoop/hbase/codec/prefixtree/decode/row/RowNodeReader.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'block' must be private and have accessor methods. 37
 Error design VisibilityModifier Variable 'offset' must be private and have accessor methods. 38
 Error design VisibilityModifier Variable 'fanIndex' must be private and have accessor methods. 39
 Error design VisibilityModifier Variable 'numCells' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'tokenOffset' must be private and have accessor methods. 43
 Error design VisibilityModifier Variable 'tokenLength' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'fanOffset' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'fanOut' must be private and have accessor methods. 46
 Error design VisibilityModifier Variable 'familyOffsetsOffset' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'qualifierOffsetsOffset' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'timestampIndexesOffset' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'mvccVersionIndexesOffset' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'operationTypesOffset' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'valueOffsetsOffset' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'valueLengthsOffset' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'tagOffsetsOffset' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'nextNodeOffsetsOffset' must be private and have accessor methods. 56
 Error sizes LineLength Line is longer than 100 characters (found 105). 77
 Error sizes LineLength Line is longer than 100 characters (found 108). 82
 Error whitespace ParenPad '(' is followed by whitespace. 227

org/apache/hadoop/hbase/codec/prefixtree/decode/timestamp/MvccVersionDecoder.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'blockMeta' must be private and have accessor methods. 31
 Error design VisibilityModifier Variable 'block' must be private and have accessor methods. 32

org/apache/hadoop/hbase/codec/prefixtree/decode/timestamp/TimestampDecoder.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'blockMeta' must be private and have accessor methods. 31
 Error design VisibilityModifier Variable 'block' must be private and have accessor methods. 32

org/apache/hadoop/hbase/codec/prefixtree/encode/EncoderFactory.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 29

org/apache/hadoop/hbase/codec/prefixtree/encode/PrefixTreeEncoder.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'numResets' must be private and have accessor methods. 73
 Error design VisibilityModifier Variable 'outputStream' must be private and have accessor methods. 75
 Error design VisibilityModifier Variable 'includeMvccVersion' must be private and have accessor methods. 81
 Error design VisibilityModifier Variable 'rowRange' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'familyRange' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'qualifierRange' must be private and have accessor methods. 88
 Error design VisibilityModifier Variable 'tagsRange' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'timestamps' must be private and have accessor methods. 94
 Error design VisibilityModifier Variable 'mvccVersions' must be private and have accessor methods. 95
 Error design VisibilityModifier Variable 'typeBytes' must be private and have accessor methods. 96
 Error design VisibilityModifier Variable 'valueOffsets' must be private and have accessor methods. 97
 Error design VisibilityModifier Variable 'tagsOffsets' must be private and have accessor methods. 98
 Error design VisibilityModifier Variable 'values' must be private and have accessor methods. 99
 Error design VisibilityModifier Variable 'tags' must be private and have accessor methods. 100
 Error design VisibilityModifier Variable 'blockMeta' must be private and have accessor methods. 102
 Error design VisibilityModifier Variable 'timestampEncoder' must be private and have accessor methods. 108
 Error design VisibilityModifier Variable 'mvccVersionEncoder' must be private and have accessor methods. 109
 Error design VisibilityModifier Variable 'cellTypeEncoder' must be private and have accessor methods. 110
 Error design VisibilityModifier Variable 'familyDeduplicator' must be private and have accessor methods. 118
 Error design VisibilityModifier Variable 'qualifierDeduplicator' must be private and have accessor methods. 119
 Error design VisibilityModifier Variable 'tagsDeduplicator' must be private and have accessor methods. 120
 Error design VisibilityModifier Variable 'rowTokenizer' must be private and have accessor methods. 125
 Error design VisibilityModifier Variable 'familyTokenizer' must be private and have accessor methods. 126
 Error design VisibilityModifier Variable 'qualifierTokenizer' must be private and have accessor methods. 127
 Error design VisibilityModifier Variable 'tagsTokenizer' must be private and have accessor methods. 128
 Error design VisibilityModifier Variable 'rowWriter' must be private and have accessor methods. 134
 Error design VisibilityModifier Variable 'familyWriter' must be private and have accessor methods. 135
 Error design VisibilityModifier Variable 'qualifierWriter' must be private and have accessor methods. 136
 Error design VisibilityModifier Variable 'tagsWriter' must be private and have accessor methods. 137
 Error design VisibilityModifier Variable 'totalCells' must be private and have accessor methods. 143
 Error design VisibilityModifier Variable 'totalUnencodedBytes' must be private and have accessor methods. 144
 Error design VisibilityModifier Variable 'totalValueBytes' must be private and have accessor methods. 145
 Error design VisibilityModifier Variable 'totalTagBytes' must be private and have accessor methods. 146
 Error design VisibilityModifier Variable 'maxValueLength' must be private and have accessor methods. 147
 Error design VisibilityModifier Variable 'maxTagLength' must be private and have accessor methods. 148
 Error design VisibilityModifier Variable 'totalBytes' must be private and have accessor methods. 149

org/apache/hadoop/hbase/codec/prefixtree/encode/column/ColumnNodeWriter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'builderNode' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'blockMeta' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'tokenLength' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'token' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'parentStartPosition' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'nodeType' must be private and have accessor methods. 55

org/apache/hadoop/hbase/codec/prefixtree/encode/column/ColumnSectionWriter.java

Severity Category Rule Message Line
 Error blocks EmptyBlock Must have at least one statement. 106

org/apache/hadoop/hbase/codec/prefixtree/encode/other/CellTypeEncoder.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'pendingFirstType' must be private and have accessor methods. 33
 Error design VisibilityModifier Variable 'allSameType' must be private and have accessor methods. 34
 Error design VisibilityModifier Variable 'onlyType' must be private and have accessor methods. 35

org/apache/hadoop/hbase/codec/prefixtree/encode/other/LongEncoder.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'uniqueValues' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'sortedUniqueValues' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'min' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'max' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'maxDelta' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'bytesPerDelta' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'bytesPerIndex' must be private and have accessor methods. 56
 Error design VisibilityModifier Variable 'totalCompressedBytes' must be private and have accessor methods. 57

org/apache/hadoop/hbase/codec/prefixtree/encode/row/RowNodeWriter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'prefixTreeEncoder' must be private and have accessor methods. 46
 Error design VisibilityModifier Variable 'blockMeta' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'tokenizerNode' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'tokenWidth' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'fanOut' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'numCells' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'width' must be private and have accessor methods. 54
 Error whitespace ParenPad '(' is followed by whitespace. 117

org/apache/hadoop/hbase/codec/prefixtree/encode/row/RowSectionWriter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'prefixTreeEncoder' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'blockMeta' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'numBytes' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'nonLeaves' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'leaves' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'leafWriters' must be private and have accessor methods. 57
 Error design VisibilityModifier Variable 'nonLeafWriters' must be private and have accessor methods. 58
 Error design VisibilityModifier Variable 'numLeafWriters' must be private and have accessor methods. 60
 Error design VisibilityModifier Variable 'numNonLeafWriters' must be private and have accessor methods. 61

org/apache/hadoop/hbase/codec/prefixtree/encode/tokenize/Tokenizer.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'numArraysAdded' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'lastNodeId' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'nodes' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'numNodes' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'root' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'tokens' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'tokensLength' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'maxElementLength' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'treeDepth' must be private and have accessor methods. 57

org/apache/hadoop/hbase/codec/prefixtree/encode/tokenize/TokenizerNode.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'builder' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'parent' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'nodeDepth' must be private and have accessor methods. 81
 Error design VisibilityModifier Variable 'tokenStartOffset' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'token' must be private and have accessor methods. 91
 Error design VisibilityModifier Variable 'numOccurrences' must be private and have accessor methods. 98
 Error design VisibilityModifier Variable 'children' must be private and have accessor methods. 104
 Error design VisibilityModifier Variable 'id' must be private and have accessor methods. 116
 Error design VisibilityModifier Variable 'firstInsertionIndex' must be private and have accessor methods. 121
 Error design VisibilityModifier Variable 'negativeIndex' must be private and have accessor methods. 127
 Error design VisibilityModifier Variable 'outputArrayOffset' must be private and have accessor methods. 133

org/apache/hadoop/hbase/codec/prefixtree/encode/tokenize/TokenizerRowSearchResult.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'difference' must be private and have accessor methods. 32
 Error design VisibilityModifier Variable 'matchingNode' must be private and have accessor methods. 33

org/apache/hadoop/hbase/codec/prefixtree/scanner/ReversibleCellScanner.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 102). 41
 Error sizes LineLength Line is longer than 100 characters (found 102). 52

org/apache/hadoop/hbase/constraint/package-info.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 127). 34
 Error sizes LineLength Line is longer than 100 characters (found 117). 35
 Error sizes LineLength Line is longer than 100 characters (found 108). 36
 Error sizes LineLength Line is longer than 100 characters (found 122). 38
 Error sizes LineLength Line is longer than 100 characters (found 136). 42
 Error sizes LineLength Line is longer than 100 characters (found 110). 44
 Error sizes LineLength Line is longer than 100 characters (found 146). 46
 Error sizes LineLength Line is longer than 100 characters (found 108). 47
 Error sizes LineLength Line is longer than 100 characters (found 114). 48
 Error sizes LineLength Line is longer than 100 characters (found 110). 55
 Error sizes LineLength Line is longer than 100 characters (found 117). 56
 Error sizes LineLength Line is longer than 100 characters (found 115). 57
 Error sizes LineLength Line is longer than 100 characters (found 117). 59
 Error sizes LineLength Line is longer than 100 characters (found 112). 63
 Error sizes LineLength Line is longer than 100 characters (found 140). 64
 Error sizes LineLength Line is longer than 100 characters (found 151). 65
 Error sizes LineLength Line is longer than 100 characters (found 128). 66
 Error sizes LineLength Line is longer than 100 characters (found 127). 68
 Error sizes LineLength Line is longer than 100 characters (found 124). 71
 Error sizes LineLength Line is longer than 100 characters (found 126). 73
 Error sizes LineLength Line is longer than 100 characters (found 107). 74
 Error sizes LineLength Line is longer than 100 characters (found 127). 75
 Error sizes LineLength Line is longer than 100 characters (found 134). 77
 Error sizes LineLength Line is longer than 100 characters (found 153). 78
 Error sizes LineLength Line is longer than 100 characters (found 147). 79
 Error sizes LineLength Line is longer than 100 characters (found 103). 83
 Error sizes LineLength Line is longer than 100 characters (found 127). 84
 Error sizes LineLength Line is longer than 100 characters (found 141). 85
 Error sizes LineLength Line is longer than 100 characters (found 108). 86
 Error sizes LineLength Line is longer than 100 characters (found 103). 93
 Error sizes LineLength Line is longer than 100 characters (found 111). 95
 Error sizes LineLength Line is longer than 100 characters (found 126). 96
 Error sizes LineLength Line is longer than 100 characters (found 131). 97
 Error sizes LineLength Line is longer than 100 characters (found 125). 98
 Error sizes LineLength Line is longer than 100 characters (found 124). 100
 Error sizes LineLength Line is longer than 100 characters (found 126). 107
 Error sizes LineLength Line is longer than 100 characters (found 101). 108
 Error sizes LineLength Line is longer than 100 characters (found 129). 111
 Error sizes LineLength Line is longer than 100 characters (found 133). 117
 Error sizes LineLength Line is longer than 100 characters (found 135). 120
 Error sizes LineLength Line is longer than 100 characters (found 101). 122
 Error sizes LineLength Line is longer than 100 characters (found 101). 150
 Error sizes LineLength Line is longer than 100 characters (found 124). 152
 Error sizes LineLength Line is longer than 100 characters (found 109). 154
 Error sizes LineLength Line is longer than 100 characters (found 119). 156
 Error sizes LineLength Line is longer than 100 characters (found 103). 169
 Error sizes LineLength Line is longer than 100 characters (found 104). 173
 Error sizes LineLength Line is longer than 100 characters (found 123). 176
 Error sizes LineLength Line is longer than 100 characters (found 103). 190
 Error sizes LineLength Line is longer than 100 characters (found 108). 193
 Error sizes LineLength Line is longer than 100 characters (found 106). 194
 Error sizes LineLength Line is longer than 100 characters (found 116). 196
 Error sizes LineLength Line is longer than 100 characters (found 104). 205
 Error sizes LineLength Line is longer than 100 characters (found 111). 218
 Error sizes LineLength Line is longer than 100 characters (found 131). 238
 Error sizes LineLength Line is longer than 100 characters (found 117). 250
 Error sizes LineLength Line is longer than 100 characters (found 106). 257
 Error sizes LineLength Line is longer than 100 characters (found 106). 258
 Error sizes LineLength Line is longer than 100 characters (found 121). 259
 Error sizes LineLength Line is longer than 100 characters (found 101). 260
 Error sizes LineLength Line is longer than 100 characters (found 104). 261

org/apache/hadoop/hbase/coordination/ZKSplitLogManagerCoordination.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'details' must be private and have accessor methods. 98
 Error design VisibilityModifier Variable 'ignoreZKDeleteForTesting' must be private and have accessor methods. 104
 Error blocks EmptyBlock Must have at least one statement. 564

org/apache/hadoop/hbase/coordination/ZKSplitTransactionCoordination.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.coordination.SplitTransactionCoordination. 27

org/apache/hadoop/hbase/coordination/ZkCoordinatedStateManager.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'server' must be private and have accessor methods. 43
 Error design VisibilityModifier Variable 'watcher' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'splitTransactionCoordination' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'closeRegionCoordination' must be private and have accessor methods. 46
 Error design VisibilityModifier Variable 'splitLogWorkerCoordination' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'splitLogManagerCoordination' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'openRegionCoordination' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'regionMergeCoordination' must be private and have accessor methods. 50

org/apache/hadoop/hbase/coordination/ZkRegionMergeCoordination.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 102). 191

org/apache/hadoop/hbase/coordination/ZkSplitLogWorkerCoordination.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'taskReadySeq' must be private and have accessor methods. 81
 Error design VisibilityModifier Variable 'tasksInProgress' must be private and have accessor methods. 89
 Error blocks EmptyBlock Must have at least one statement. 160
 Error coding InnerAssignment Inner assignments should be avoided. 222

org/apache/hadoop/hbase/coprocessor/AggregateImplementation.java

Severity Category Rule Message Line
 Error blocks EmptyBlock Must have at least one statement. 113
 Error whitespace ParenPad '(' is followed by whitespace. 157
 Error blocks EmptyBlock Must have at least one statement. 166
 Error misc UpperEll Should use uppercase 'L'. 186
 Error whitespace ParenPad '(' is followed by whitespace. 212
 Error blocks EmptyBlock Must have at least one statement. 221
 Error misc UpperEll Should use uppercase 'L'. 238
 Error whitespace ParenPad '(' is followed by whitespace. 264
 Error blocks EmptyBlock Must have at least one statement. 272
 Error misc UpperEll Should use uppercase 'L'. 301
 Error blocks EmptyBlock Must have at least one statement. 338
 Error misc UpperEll Should use uppercase 'L'. 361
 Error blocks EmptyBlock Must have at least one statement. 404
 Error blocks EmptyBlock Must have at least one statement. 471

org/apache/hadoop/hbase/coprocessor/BaseMasterAndRegionObserver.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 30 - org.apache.hadoop.hbase.CoprocessorEnvironment. 36
 Error imports RedundantImport Duplicate import to line 26 - java.io.IOException. 46
 Error imports RedundantImport Duplicate import to line 27 - java.util.List. 47

org/apache/hadoop/hbase/coprocessor/BaseMasterObserver.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 30 - org.apache.hadoop.hbase.CoprocessorEnvironment. 36
 Error imports RedundantImport Duplicate import to line 26 - java.io.IOException. 46
 Error imports RedundantImport Duplicate import to line 27 - java.util.List. 47

org/apache/hadoop/hbase/coprocessor/BaseRegionObserver.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 101). 299

org/apache/hadoop/hbase/coprocessor/CoprocessorException.java

Severity Category Rule Message Line
 Error whitespace ParenPad '(' is followed by whitespace. 44

org/apache/hadoop/hbase/coprocessor/CoprocessorHost.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'abortable' must be private and have accessor methods. 84
 Error design VisibilityModifier Variable 'coprocessors' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 88
 Error design VisibilityModifier Variable 'pathPrefix' must be private and have accessor methods. 90
 Error design VisibilityModifier Variable 'loadSequence' must be private and have accessor methods. 91
 Error whitespace ParenPad ')' is preceded with whitespace. 342
 Error design VisibilityModifier Variable 'impl' must be private and have accessor methods. 379
 Error design VisibilityModifier Variable 'priority' must be private and have accessor methods. 381
 Error design VisibilityModifier Variable 'state' must be private and have accessor methods. 383
 Error design VisibilityModifier Variable 'openTables' must be private and have accessor methods. 385

org/apache/hadoop/hbase/coprocessor/RegionObserver.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.OperationStatus. 53
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 128
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 148
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 353
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 373
 Error sizes LineLength Line is longer than 100 characters (found 101). 395
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1237

org/apache/hadoop/hbase/coprocessor/example/BulkDeleteEndpoint.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 101). 91
 Error sizes LineLength Line is longer than 100 characters (found 104). 230

org/apache/hadoop/hbase/coprocessor/example/RowCountEndpoint.java

Severity Category Rule Message Line
 Error blocks EmptyBlock Must have at least one statement. 102
 Error blocks EmptyBlock Must have at least one statement. 137

org/apache/hadoop/hbase/coprocessor/example/ZooKeeperScanPolicyObserver.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 36 - org.apache.hadoop.hbase.regionserver.Store. 41
 Error blocks EmptyBlock Must have at least one statement. 139
 Error blocks EmptyBlock Must have at least one statement. 150

org/apache/hadoop/hbase/coprocessor/package-info.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 154). 217

org/apache/hadoop/hbase/errorhandling/ForeignExceptionDispatcher.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'name' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'listeners' must be private and have accessor methods. 45

org/apache/hadoop/hbase/errorhandling/TimeoutException.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 112). 41

org/apache/hadoop/hbase/executor/EventHandler.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'eventType' must be private and have accessor methods. 63
 Error design VisibilityModifier Variable 'server' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'waitingTimeForEvents' must be private and have accessor methods. 77

org/apache/hadoop/hbase/executor/ExecutorService.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'threadPoolExecutor' must be private and have accessor methods. 194
 Error design VisibilityModifier Variable 'q' must be private and have accessor methods. 196
 Error design VisibilityModifier Variable 'executor' must be private and have accessor methods. 310
 Error design VisibilityModifier Variable 'queuedEvents' must be private and have accessor methods. 311
 Error design VisibilityModifier Variable 'running' must be private and have accessor methods. 312
 Error design VisibilityModifier Variable 'threadInfo' must be private and have accessor methods. 361
 Error design VisibilityModifier Variable 'event' must be private and have accessor methods. 362

org/apache/hadoop/hbase/filter/BitComparator.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'bitOperator' must be private and have accessor methods. 47
 Error coding MissingSwitchDefault switch without "default" clause. 119

org/apache/hadoop/hbase/filter/ByteArrayComparable.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'value' must be private and have accessor methods. 34

org/apache/hadoop/hbase/filter/ColumnPaginationFilter.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 115). 37
 Error sizes LineLength Line is longer than 100 characters (found 110). 38

org/apache/hadoop/hbase/filter/ColumnPrefixFilter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'prefix' must be private and have accessor methods. 44

org/apache/hadoop/hbase/filter/ColumnRangeFilter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'minColumn' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'minColumnInclusive' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'maxColumn' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'maxColumnInclusive' must be private and have accessor methods. 56

org/apache/hadoop/hbase/filter/CompareFilter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'compareOp' must be private and have accessor methods. 72
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 73
 Error whitespace MethodParamPad '(' is preceded with whitespace. 145

org/apache/hadoop/hbase/filter/DependentColumnFilter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'columnFamily' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'columnQualifier' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'dropDependentColumn' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'stampSet' must be private and have accessor methods. 56

org/apache/hadoop/hbase/filter/FamilyFilter.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 144). 39
 Error sizes LineLength Line is longer than 100 characters (found 116). 44

org/apache/hadoop/hbase/filter/Filter.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 101). 43
 Error design VisibilityModifier Variable 'reversed' must be private and have accessor methods. 59
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 142
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 218

org/apache/hadoop/hbase/filter/FilterBase.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 91
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 133

org/apache/hadoop/hbase/filter/FilterList.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 234
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 416

org/apache/hadoop/hbase/filter/FilterWrapper.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'filter' must be private and have accessor methods. 44
 Error whitespace ParenPad '(' is followed by whitespace. 46
 Error whitespace ParenPad ')' is preceded with whitespace. 46
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 103
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 135

org/apache/hadoop/hbase/filter/FirstKeyValueMatchingQualifiersFilter.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 102). 96

org/apache/hadoop/hbase/filter/FuzzyRowFilter.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 107). 208

org/apache/hadoop/hbase/filter/InclusiveStopFilter.java

Severity Category Rule Message Line
 Error whitespace MethodParamPad '(' is preceded with whitespace. 90

org/apache/hadoop/hbase/filter/KeyOnlyFilter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'lenAsVal' must be private and have accessor methods. 48

org/apache/hadoop/hbase/filter/MultipleColumnPrefixFilter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'hint' must be private and have accessor methods. 43
 Error design VisibilityModifier Variable 'sortedPrefixes' must be private and have accessor methods. 44
 Error whitespace MethodParamPad '(' is preceded with whitespace. 51
 Error whitespace MethodParamPad '(' is preceded with whitespace. 173
 Error whitespace MethodParamPad '(' is preceded with whitespace. 175
 Error whitespace MethodParamPad '(' is preceded with whitespace. 179

org/apache/hadoop/hbase/filter/ParseConstants.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 30

org/apache/hadoop/hbase/filter/ParseFilter.java

Severity Category Rule Message Line
 Error whitespace MethodParamPad '(' is preceded with whitespace. 112
 Error whitespace MethodParamPad '(' is preceded with whitespace. 123
 Error whitespace MethodParamPad '(' is preceded with whitespace. 206
 Error whitespace ParenPad ')' is preceded with whitespace. 219
 Error whitespace MethodParamPad '(' is preceded with whitespace. 235
 Error whitespace MethodParamPad '(' is preceded with whitespace. 268
 Error whitespace MethodParamPad '(' is preceded with whitespace. 296
 Error whitespace MethodParamPad '(' is preceded with whitespace. 384
 Error whitespace MethodParamPad '(' is preceded with whitespace. 479
 Error whitespace MethodParamPad '(' is preceded with whitespace. 517
 Error whitespace MethodParamPad '(' is preceded with whitespace. 543
 Error whitespace MethodParamPad '(' is preceded with whitespace. 570
 Error whitespace MethodParamPad '(' is preceded with whitespace. 600
 Error whitespace MethodParamPad '(' is preceded with whitespace. 630
 Error whitespace MethodParamPad '(' is preceded with whitespace. 651
 Error whitespace MethodParamPad '(' is preceded with whitespace. 673
 Error whitespace MethodParamPad '(' is preceded with whitespace. 696
 Error whitespace MethodParamPad '(' is preceded with whitespace. 739
 Error whitespace MethodParamPad '(' is preceded with whitespace. 770
 Error whitespace MethodParamPad '(' is preceded with whitespace. 794
 Error whitespace MethodParamPad '(' is preceded with whitespace. 820
 Error whitespace MethodParamPad '(' is preceded with whitespace. 840

org/apache/hadoop/hbase/filter/PrefixFilter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'prefix' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'passedPrefix' must be private and have accessor methods. 42
 Error design VisibilityModifier Variable 'filterRow' must be private and have accessor methods. 43

org/apache/hadoop/hbase/filter/RandomRowFilter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'chance' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'filterOutRow' must be private and have accessor methods. 42

org/apache/hadoop/hbase/filter/RegexStringComparator.java

Severity Category Rule Message Line
 Error coding MissingSwitchDefault switch without "default" clause. 126

org/apache/hadoop/hbase/filter/SingleColumnValueExcludeFilter.java

Severity Category Rule Message Line
 Error whitespace MethodParamPad '(' is preceded with whitespace. 121

org/apache/hadoop/hbase/filter/SingleColumnValueFilter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'columnFamily' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'columnQualifier' must be private and have accessor methods. 77
 Error design VisibilityModifier Variable 'compareOp' must be private and have accessor methods. 78
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 79
 Error design VisibilityModifier Variable 'foundColumn' must be private and have accessor methods. 80
 Error design VisibilityModifier Variable 'matchedColumn' must be private and have accessor methods. 81
 Error design VisibilityModifier Variable 'filterIfMissing' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'latestVersionOnly' must be private and have accessor methods. 83
 Error whitespace MethodParamPad '(' is preceded with whitespace. 290

org/apache/hadoop/hbase/filter/TimestampsFilter.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 135). 38
 Error design VisibilityModifier Variable 'timestamps' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'minTimeStamp' must be private and have accessor methods. 50

org/apache/hadoop/hbase/fs/HFileSystem.java

Severity Category Rule Message Line
 Error whitespace MethodParamPad '(' should be on the previous line. 269

org/apache/hadoop/hbase/http/HtmlQuoting.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 27
 Error blocks EmptyBlock Must have at least one statement. 110

org/apache/hadoop/hbase/http/HttpRequestLog.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 34

org/apache/hadoop/hbase/http/HttpServer.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.Arrays. 30
 Error design VisibilityModifier Variable 'webServer' must be private and have accessor methods. 140
 Error design VisibilityModifier Variable 'appDir' must be private and have accessor methods. 141
 Error design VisibilityModifier Variable 'logDir' must be private and have accessor methods. 142
 Error design FinalClass Class ListenerInfo should be declared as final. 144
 Error design VisibilityModifier Variable 'webAppContext' must be private and have accessor methods. 159
 Error design VisibilityModifier Variable 'findPort' must be private and have accessor methods. 160
 Error design VisibilityModifier Variable 'defaultContexts' must be private and have accessor methods. 161
 Error design VisibilityModifier Variable 'filterNames' must be private and have accessor methods. 163
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 200
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 202
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 204
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 263
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 272
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 281
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 428
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 434
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 454
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 469
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 475
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 494
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 515
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 935
 Error sizes LineLength Line is longer than 100 characters (found 109). 1183
 Error whitespace MethodParamPad '(' should be on the previous line. 1349

org/apache/hadoop/hbase/http/InfoServer.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 103

org/apache/hadoop/hbase/http/ServerConfigurationKeys.java

Severity Category Rule Message Line
 Error design InterfaceIsType interfaces should describe a type and hence have methods. 27

org/apache/hadoop/hbase/http/jmx/JMXJsonServlet.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - javax.management.ReflectionException. 27
 Error imports UnusedImports Unused import - javax.management.RuntimeErrorException. 28
 Error imports UnusedImports Unused import - javax.management.RuntimeMBeanException. 29
 Error imports UnusedImports Unused import - javax.management.openmbean.CompositeData. 30
 Error imports UnusedImports Unused import - javax.management.openmbean.TabularData. 31
 Error design VisibilityModifier Variable 'mBeanServer' must be private and have accessor methods. 125
 Error design VisibilityModifier Variable 'jsonBeanWriter' must be private and have accessor methods. 127

org/apache/hadoop/hbase/http/log/LogLevel.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 45
 Error coding InnerAssignment Inner assignments should be avoided. 78
 Error coding InnerAssignment Inner assignments should be avoided. 171
 Error coding EmptyStatement Empty statement. 171

org/apache/hadoop/hbase/io/BoundedByteBufferPool.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'buffers' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'runningAverage' must be private and have accessor methods. 60

org/apache/hadoop/hbase/io/ByteBufferOutputStream.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'buf' must be private and have accessor methods. 44

org/apache/hadoop/hbase/io/DataOutputOutputStream.java

Severity Category Rule Message Line
 Error design FinalClass Class DataOutputOutputStream should be declared as final. 29

org/apache/hadoop/hbase/io/FSDataInputStreamWrapper.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.io.FileLink. 31
 Error coding InnerAssignment Inner assignments should be avoided. 110
 Error coding InnerAssignment Inner assignments should be avoided. 129
 Error coding InnerAssignment Inner assignments should be avoided. 151

org/apache/hadoop/hbase/io/FileLink.java

Severity Category Rule Message Line
 Error blocks EmptyBlock Must have at least one statement. 304
 Error blocks EmptyBlock Must have at least one statement. 390

org/apache/hadoop/hbase/io/HalfStoreFileReader.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'LOG' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'top' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'splitkey' must be private and have accessor methods. 58
 Error design VisibilityModifier Variable 'splitCell' must be private and have accessor methods. 60
 Error sizes MethodLength Method length is 209 lines (max allowed is 150). 120
 Error design VisibilityModifier Variable 'delegate' must be private and have accessor methods. 125
 Error design VisibilityModifier Variable 'atEnd' must be private and have accessor methods. 126

org/apache/hadoop/hbase/io/compress/Compression.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 65
 Error sizes LineLength Line is longer than 100 characters (found 102). 328

org/apache/hadoop/hbase/io/crypto/Encryption.java

Severity Category Rule Message Line
 Error design FinalClass Class Context should be declared as final. 59
 Error misc ArrayTypeStyle Array brackets at illegal position. 384

org/apache/hadoop/hbase/io/crypto/KeyStoreKeyProvider.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'store' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'password' must be private and have accessor methods. 77
 Error design VisibilityModifier Variable 'passwordFile' must be private and have accessor methods. 78

org/apache/hadoop/hbase/io/encoding/BufferedDataBlockEncoder.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'currentBuffer' must be private and have accessor methods. 83
 Error design VisibilityModifier Variable 'tagCompressionContext' must be private and have accessor methods. 84
 Error design VisibilityModifier Variable 'valueOffset' must be private and have accessor methods. 85
 Error design VisibilityModifier Variable 'keyLength' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'valueLength' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'lastCommonPrefix' must be private and have accessor methods. 88
 Error design VisibilityModifier Variable 'tagsLength' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'tagsOffset' must be private and have accessor methods. 90
 Error design VisibilityModifier Variable 'tagsCompressedLength' must be private and have accessor methods. 91
 Error design VisibilityModifier Variable 'uncompressTags' must be private and have accessor methods. 92
 Error design VisibilityModifier Variable 'keyBuffer' must be private and have accessor methods. 95
 Error design VisibilityModifier Variable 'tagsBuffer' must be private and have accessor methods. 96
 Error design VisibilityModifier Variable 'memstoreTS' must be private and have accessor methods. 98
 Error design VisibilityModifier Variable 'nextKvOffset' must be private and have accessor methods. 99
 Error design VisibilityModifier Variable 'currentKey' must be private and have accessor methods. 100
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 281
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 287
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 293
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 299
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 433
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 480
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 486
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 492
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 498
 Error design VisibilityModifier Variable 'decodingCtx' must be private and have accessor methods. 524
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 525
 Error design VisibilityModifier Variable 'samePrefixComparator' must be private and have accessor methods. 526
 Error design VisibilityModifier Variable 'currentBuffer' must be private and have accessor methods. 527
 Error design VisibilityModifier Variable 'current' must be private and have accessor methods. 528
 Error design VisibilityModifier Variable 'previous' must be private and have accessor methods. 529
 Error design VisibilityModifier Variable 'tagCompressionContext' must be private and have accessor methods. 530
 Error whitespace MethodParamPad '(' is preceded with whitespace. 953
 Error design VisibilityModifier Variable 'unencodedDataSizeWritten' must be private and have accessor methods. 982

org/apache/hadoop/hbase/io/encoding/CompressionState.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'keyLength' must be private and have accessor methods. 30
 Error design VisibilityModifier Variable 'valueLength' must be private and have accessor methods. 31
 Error design VisibilityModifier Variable 'rowLength' must be private and have accessor methods. 33
 Error design VisibilityModifier Variable 'prevOffset' must be private and have accessor methods. 34
 Error design VisibilityModifier Variable 'familyLength' must be private and have accessor methods. 35
 Error design VisibilityModifier Variable 'qualifierLength' must be private and have accessor methods. 36
 Error design VisibilityModifier Variable 'type' must be private and have accessor methods. 37

org/apache/hadoop/hbase/io/encoding/DataBlockEncoder.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 193

org/apache/hadoop/hbase/io/encoding/DiffKeyDeltaEncoder.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'timestamp' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'familyNameWithSize' must be private and have accessor methods. 66

org/apache/hadoop/hbase/io/encoding/EncodingState.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'prevCell' must be private and have accessor methods. 33

org/apache/hadoop/hbase/io/encoding/FastDiffDeltaEncoder.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'MASK_TIMESTAMP_LENGTH' must be private and have accessor methods. 60
 Error design VisibilityModifier Variable 'SHIFT_TIMESTAMP_LENGTH' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'FLAG_SAME_KEY_LENGTH' must be private and have accessor methods. 62
 Error design VisibilityModifier Variable 'FLAG_SAME_VALUE_LENGTH' must be private and have accessor methods. 63
 Error design VisibilityModifier Variable 'FLAG_SAME_TYPE' must be private and have accessor methods. 64
 Error design VisibilityModifier Variable 'FLAG_SAME_VALUE' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'timestamp' must be private and have accessor methods. 68
 Error design VisibilityModifier Variable 'prevTimestampOffset' must be private and have accessor methods. 69

org/apache/hadoop/hbase/io/encoding/HFileBlockDecodingContext.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 104). 36

org/apache/hadoop/hbase/io/hfile/AbstractHFileReader.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'istream' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'istreamNoFsChecksum' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'dataBlockIndexReader' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'metaBlockIndexReader' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'trailer' must be private and have accessor methods. 56
 Error design VisibilityModifier Variable 'compressAlgo' must be private and have accessor methods. 59
 Error design VisibilityModifier Variable 'dataBlockEncoder' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'lastKey' must be private and have accessor methods. 71
 Error design VisibilityModifier Variable 'avgKeyLen' must be private and have accessor methods. 74
 Error design VisibilityModifier Variable 'avgValueLen' must be private and have accessor methods. 77
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 80
 Error design VisibilityModifier Variable 'fileSize' must be private and have accessor methods. 83
 Error design VisibilityModifier Variable 'cacheConf' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'path' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'name' must be private and have accessor methods. 92
 Error design VisibilityModifier Variable 'fileInfo' must be private and have accessor methods. 94
 Error design VisibilityModifier Variable 'hfs' must be private and have accessor methods. 97
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 99
 Error design VisibilityModifier Variable 'blockBuffer' must be private and have accessor methods. 281
 Error design VisibilityModifier Variable 'cacheBlocks' must be private and have accessor methods. 283
 Error design VisibilityModifier Variable 'pread' must be private and have accessor methods. 284
 Error design VisibilityModifier Variable 'isCompaction' must be private and have accessor methods. 285
 Error design VisibilityModifier Variable 'currKeyLen' must be private and have accessor methods. 287
 Error design VisibilityModifier Variable 'currValueLen' must be private and have accessor methods. 288
 Error design VisibilityModifier Variable 'currMemstoreTSLen' must be private and have accessor methods. 289
 Error design VisibilityModifier Variable 'currMemstoreTS' must be private and have accessor methods. 290
 Error design VisibilityModifier Variable 'blockFetches' must be private and have accessor methods. 292
 Error design VisibilityModifier Variable 'reader' must be private and have accessor methods. 294

org/apache/hadoop/hbase/io/hfile/AbstractHFileWriter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'lastCell' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'outputStream' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'closeOutputStream' must be private and have accessor methods. 58
 Error design VisibilityModifier Variable 'fileInfo' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'entryCount' must be private and have accessor methods. 64
 Error design VisibilityModifier Variable 'totalKeyLength' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'totalValueLength' must be private and have accessor methods. 70
 Error design VisibilityModifier Variable 'totalUncompressedBytes' must be private and have accessor methods. 73
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'metaNames' must be private and have accessor methods. 79
 Error design VisibilityModifier Variable 'metaData' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'firstCellInBlock' must be private and have accessor methods. 88
 Error design VisibilityModifier Variable 'path' must be private and have accessor methods. 91
 Error design VisibilityModifier Variable 'cacheConf' must be private and have accessor methods. 95
 Error design VisibilityModifier Variable 'name' must be private and have accessor methods. 101
 Error design VisibilityModifier Variable 'blockEncoder' must be private and have accessor methods. 107
 Error design VisibilityModifier Variable 'hFileContext' must be private and have accessor methods. 109

org/apache/hadoop/hbase/io/hfile/BlockCacheKey.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 102). 45

org/apache/hadoop/hbase/io/hfile/BlockCacheUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 39
 Error design VisibilityModifier Variable 'hist' must be private and have accessor methods. 199

org/apache/hadoop/hbase/io/hfile/BlockCachesIterator.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'index' must be private and have accessor methods. 31
 Error design VisibilityModifier Variable 'bcs' must be private and have accessor methods. 32
 Error design VisibilityModifier Variable 'current' must be private and have accessor methods. 33

org/apache/hadoop/hbase/io/hfile/CacheConfig.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'clazz' must be private and have accessor methods. 150
 Error design VisibilityModifier Variable 'GLOBAL_BLOCK_CACHE_INSTANCE' must be private and have accessor methods. 512
 Error design VisibilityModifier Variable 'blockCacheDisabled' must be private and have accessor methods. 516

org/apache/hadoop/hbase/io/hfile/CacheStats.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.concurrent.atomic.AtomicLong. 21

org/apache/hadoop/hbase/io/hfile/CacheableDeserializerIdManager.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 31

org/apache/hadoop/hbase/io/hfile/ChecksumUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 33

org/apache/hadoop/hbase/io/hfile/CombinedBlockCache.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketCache. 26
 Error design VisibilityModifier Variable 'lruCache' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'l2Cache' must be private and have accessor methods. 42
 Error design VisibilityModifier Variable 'combinedCacheStats' must be private and have accessor methods. 43

org/apache/hadoop/hbase/io/hfile/FixedFileTrailer.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 128
 Error misc ArrayTypeStyle Array brackets at illegal position. 149
 Error sizes LineLength Line is longer than 100 characters (found 101). 571

org/apache/hadoop/hbase/io/hfile/HFile.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 101). 124
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 136
 Error sizes LineLength Line is longer than 100 characters (found 113). 241
 Error sizes LineLength Line is longer than 100 characters (found 116). 242
 Error sizes LineLength Line is longer than 100 characters (found 118). 243
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 272
 Error design VisibilityModifier Variable 'cacheConf' must be private and have accessor methods. 273
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 274
 Error design VisibilityModifier Variable 'path' must be private and have accessor methods. 275
 Error design VisibilityModifier Variable 'ostream' must be private and have accessor methods. 276
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 277
 Error design VisibilityModifier Variable 'favoredNodes' must be private and have accessor methods. 278
 Error sizes LineLength Line is longer than 100 characters (found 130). 567
 Error sizes LineLength Line is longer than 100 characters (found 120). 569
 Error sizes LineLength Line is longer than 100 characters (found 106). 646
 Error sizes LineLength Line is longer than 100 characters (found 117). 819
 Error sizes LineLength Line is longer than 100 characters (found 114). 820
 Error sizes LineLength Line is longer than 100 characters (found 115). 821
 Error sizes LineLength Line is longer than 100 characters (found 114). 827
 Error sizes LineLength Line is longer than 100 characters (found 114). 828
 Error sizes LineLength Line is longer than 100 characters (found 106). 833
 Error sizes LineLength Line is longer than 100 characters (found 120). 840

org/apache/hadoop/hbase/io/hfile/HFileBlock.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 101). 426
 Error design VisibilityModifier Variable 'fileSize' must be private and have accessor methods. 1322
 Error design VisibilityModifier Variable 'hdrSize' must be private and have accessor methods. 1325
 Error design VisibilityModifier Variable 'hfs' must be private and have accessor methods. 1328
 Error design VisibilityModifier Variable 'streamLock' must be private and have accessor methods. 1330
 Error design VisibilityModifier Variable 'fileContext' must be private and have accessor methods. 1335
 Error design VisibilityModifier Variable 'pathName' must be private and have accessor methods. 1337
 Error design VisibilityModifier Variable 'offset' must be private and have accessor methods. 1453
 Error design VisibilityModifier Variable 'header' must be private and have accessor methods. 1454
 Error design VisibilityModifier Variable 'buf' must be private and have accessor methods. 1455
 Error design VisibilityModifier Variable 'streamWrapper' must be private and have accessor methods. 1462
 Error sizes MethodLength Method length is 159 lines (max allowed is 150). 1585
 Error coding EqualsHashCode Definition of 'equals()' without corresponding definition of 'hashCode()'. 1830

org/apache/hadoop/hbase/io/hfile/HFileBlockIndex.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 61
 Error whitespace MethodParamPad '(' is preceded with whitespace. 1170

org/apache/hadoop/hbase/io/hfile/HFilePrettyPrinter.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 162
 Error whitespace MethodParamPad '(' is preceded with whitespace. 544
 Error sizes LineLength Line is longer than 100 characters (found 118). 580
 Error design VisibilityModifier Variable 'keyLen' must be private and have accessor methods. 581
 Error design VisibilityModifier Variable 'valLen' must be private and have accessor methods. 582
 Error sizes LineLength Line is longer than 100 characters (found 104). 583
 Error design VisibilityModifier Variable 'rowSizeBytes' must be private and have accessor methods. 583
 Error sizes LineLength Line is longer than 100 characters (found 105). 584
 Error design VisibilityModifier Variable 'rowSizeCols' must be private and have accessor methods. 584
 Error design VisibilityModifier Variable 'curRowBytes' must be private and have accessor methods. 586
 Error design VisibilityModifier Variable 'curRowCols' must be private and have accessor methods. 587
 Error design VisibilityModifier Variable 'biggestRow' must be private and have accessor methods. 589
 Error sizes LineLength Line is longer than 100 characters (found 104). 654

org/apache/hadoop/hbase/io/hfile/HFileReaderV2.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'decodeMemstoreTS' must be private and have accessor methods. 74
 Error design VisibilityModifier Variable 'hfileContext' must be private and have accessor methods. 108
 Error design VisibilityModifier Variable 'block' must be private and have accessor methods. 547
 Error design VisibilityModifier Variable 'nextIndexedKey' must be private and have accessor methods. 560
 Error design VisibilityModifier Variable 'meta' must be private and have accessor methods. 1167

org/apache/hadoop/hbase/io/hfile/HFileReaderV3.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.NoTagsKeyValue. 33
 Error whitespace ParenPad ')' is preceded with whitespace. 139

org/apache/hadoop/hbase/io/hfile/HFileScanner.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 57
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 59
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 83
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 85
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 99
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 101

org/apache/hadoop/hbase/io/hfile/HFileUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 24
 Error sizes LineLength Line is longer than 100 characters (found 103). 33

org/apache/hadoop/hbase/io/hfile/HFileWriterV2.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'fsBlockWriter' must be private and have accessor methods. 68
 Error design VisibilityModifier Variable 'lastDataBlockOffset' must be private and have accessor methods. 77
 Error design VisibilityModifier Variable 'maxMemstoreTS' must be private and have accessor methods. 89

org/apache/hadoop/hbase/io/hfile/LruBlockCache.java

Severity Category Rule Message Line
 Error coding MissingSwitchDefault switch without "default" clause. 559

org/apache/hadoop/hbase/io/hfile/NoOpDataBlockEncoder.java

Severity Category Rule Message Line
 Error design FinalClass Class NoOpDataBlockEncoder should be declared as final. 37

org/apache/hadoop/hbase/io/hfile/PrefetchExecutor.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 40

org/apache/hadoop/hbase/io/hfile/bucket/BucketAllocator.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.ArrayList. 23
 Error misc ArrayTypeStyle Array brackets at illegal position. 64
 Error misc ArrayTypeStyle Array brackets at illegal position. 281
 Error misc ArrayTypeStyle Array brackets at illegal position. 556
 Error whitespace ParenPad ')' is preceded with whitespace. 591

org/apache/hadoop/hbase/io/hfile/bucket/BucketCache.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'ioEngine' must be private and have accessor methods. 118
 Error design VisibilityModifier Variable 'ramCache' must be private and have accessor methods. 122
 Error design VisibilityModifier Variable 'backingMap' must be private and have accessor methods. 125
 Error design VisibilityModifier Variable 'writerQueues' must be private and have accessor methods. 142
 Error design VisibilityModifier Variable 'writerThreads' must be private and have accessor methods. 145
 Error design VisibilityModifier Variable 'wait_when_cache' must be private and have accessor methods. 166
 Error design VisibilityModifier Variable 'offsetLock' must be private and have accessor methods. 189
 Error coding MissingSwitchDefault switch without "default" clause. 672
 Error design VisibilityModifier Variable 'deserialiserIndex' must be private and have accessor methods. 1133
 Error sizes LineLength Line is longer than 100 characters (found 130). 1153
 Error sizes LineLength Line is longer than 100 characters (found 127). 1154
 Error coding EqualsHashCode Definition of 'equals()' without corresponding definition of 'hashCode()'. 1252

org/apache/hadoop/hbase/io/hfile/bucket/UniqueIndexMap.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'mForwardMap' must be private and have accessor methods. 35
 Error design VisibilityModifier Variable 'mReverseMap' must be private and have accessor methods. 36
 Error design VisibilityModifier Variable 'mIndex' must be private and have accessor methods. 37

org/apache/hadoop/hbase/io/util/HeapMemorySizeUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 29
 Error sizes LineLength Line is longer than 100 characters (found 105). 96

org/apache/hadoop/hbase/io/util/LRUDictionary.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'backingStore' must be private and have accessor methods. 40
 Error coding InnerAssignment Inner assignments should be avoided. 122
 Error design VisibilityModifier Variable 'container' must be private and have accessor methods. 187
 Error design VisibilityModifier Variable 'offset' must be private and have accessor methods. 188
 Error design VisibilityModifier Variable 'length' must be private and have accessor methods. 189
 Error design VisibilityModifier Variable 'next' must be private and have accessor methods. 190
 Error design VisibilityModifier Variable 'prev' must be private and have accessor methods. 191

org/apache/hadoop/hbase/io/util/StreamUtils.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 38
 Error coding InnerAssignment Inner assignments should be avoided. 59
 Error coding InnerAssignment Inner assignments should be avoided. 63
 Error coding InnerAssignment Inner assignments should be avoided. 67
 Error coding InnerAssignment Inner assignments should be avoided. 71
 Error coding InnerAssignment Inner assignments should be avoided. 93
 Error coding InnerAssignment Inner assignments should be avoided. 97
 Error coding InnerAssignment Inner assignments should be avoided. 101
 Error coding InnerAssignment Inner assignments should be avoided. 105
 Error sizes LineLength Line is longer than 100 characters (found 101). 132

org/apache/hadoop/hbase/ipc/AbstractRpcClient.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'clusterId' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'localAddr' must be private and have accessor methods. 56
 Error design VisibilityModifier Variable 'userProvider' must be private and have accessor methods. 58
 Error design VisibilityModifier Variable 'ipcUtil' must be private and have accessor methods. 59
 Error design VisibilityModifier Variable 'minIdleTimeBeforeClose' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'maxRetries' must be private and have accessor methods. 63
 Error design VisibilityModifier Variable 'failureSleep' must be private and have accessor methods. 64
 Error design VisibilityModifier Variable 'tcpNoDelay' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'tcpKeepAlive' must be private and have accessor methods. 66
 Error design VisibilityModifier Variable 'codec' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'compressor' must be private and have accessor methods. 68
 Error design VisibilityModifier Variable 'fallbackAllowed' must be private and have accessor methods. 69
 Error design VisibilityModifier Variable 'connectTO' must be private and have accessor methods. 71
 Error design VisibilityModifier Variable 'readTO' must be private and have accessor methods. 72
 Error design VisibilityModifier Variable 'writeTO' must be private and have accessor methods. 73

org/apache/hadoop/hbase/ipc/AdaptiveLifoCoDelCallQueue.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.concurrent.LinkedBlockingQueue. 24

org/apache/hadoop/hbase/ipc/AsyncCall.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'id' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'method' must be private and have accessor methods. 46
 Error design VisibilityModifier Variable 'param' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'controller' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'responseDefaultType' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'startTime' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'rpcTimeout' must be private and have accessor methods. 51

org/apache/hadoop/hbase/ipc/AsyncRpcChannel.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'client' must be private and have accessor methods. 95
 Error design VisibilityModifier Variable 'name' must be private and have accessor methods. 101
 Error design VisibilityModifier Variable 'ticket' must be private and have accessor methods. 102
 Error design VisibilityModifier Variable 'serviceName' must be private and have accessor methods. 103
 Error design VisibilityModifier Variable 'address' must be private and have accessor methods. 104
 Error design VisibilityModifier Variable 'useSasl' must be private and have accessor methods. 109
 Error design VisibilityModifier Variable 'authMethod' must be private and have accessor methods. 110

org/apache/hadoop/hbase/ipc/AsyncRpcClient.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'callIdCnt' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'failedServers' must be private and have accessor methods. 91
 Error design VisibilityModifier Variable 'bootstrap' must be private and have accessor methods. 94
 Error design VisibilityModifier Variable 'GLOBAL_EVENT_LOOP_GROUP' must be private and have accessor methods. 99

org/apache/hadoop/hbase/ipc/BalancedQueueRpcExecutor.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'queues' must be private and have accessor methods. 41

org/apache/hadoop/hbase/ipc/Call.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'id' must be private and have accessor methods. 32
 Error design VisibilityModifier Variable 'param' must be private and have accessor methods. 33
 Error design VisibilityModifier Variable 'cells' must be private and have accessor methods. 38
 Error design VisibilityModifier Variable 'response' must be private and have accessor methods. 39
 Error design VisibilityModifier Variable 'responseDefaultType' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'error' must be private and have accessor methods. 42
 Error design VisibilityModifier Variable 'done' must be private and have accessor methods. 43
 Error design VisibilityModifier Variable 'startTime' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'md' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'timeout' must be private and have accessor methods. 46

org/apache/hadoop/hbase/ipc/ConnectionId.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'ticket' must be private and have accessor methods. 32
 Error design VisibilityModifier Variable 'serviceName' must be private and have accessor methods. 33
 Error design VisibilityModifier Variable 'address' must be private and have accessor methods. 34

org/apache/hadoop/hbase/ipc/FastPathBalancedQueueRpcExecutor.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.concurrent.atomic.AtomicLong. 25
 Error sizes LineLength Line is longer than 100 characters (found 114). 48
 Error design VisibilityModifier Variable 'fastPathHandlerStack' must be private and have accessor methods. 85

org/apache/hadoop/hbase/ipc/MasterCoprocessorRpcChannel.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.ByteStringer. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.HConnection. 28
 Error sizes LineLength Line is longer than 100 characters (found 108). 39
 Error sizes LineLength Line is longer than 100 characters (found 115). 42

org/apache/hadoop/hbase/ipc/MetricsHBaseServerSourceFactoryImpl.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'sources' must be private and have accessor methods. 31

org/apache/hadoop/hbase/ipc/RegionCoprocessorRpcChannel.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.ByteStringer. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HConstants. 27
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.HConnection. 29
 Error sizes LineLength Line is longer than 100 characters (found 108). 43
 Error sizes LineLength Line is longer than 100 characters (found 115). 46

org/apache/hadoop/hbase/ipc/RegionServerCoprocessorRpcChannel.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 107). 34

org/apache/hadoop/hbase/ipc/RemoteWithExtrasException.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.ProtobufUtil. 28

org/apache/hadoop/hbase/ipc/RpcClientImpl.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.UserProvider. 48
 Error design VisibilityModifier Variable 'callIdCnt' must be private and have accessor methods. 106
 Error design VisibilityModifier Variable 'connections' must be private and have accessor methods. 108
 Error design VisibilityModifier Variable 'running' must be private and have accessor methods. 110
 Error design VisibilityModifier Variable 'failedServers' must be private and have accessor methods. 112
 Error design VisibilityModifier Variable 'socketFactory' must be private and have accessor methods. 114
 Error design VisibilityModifier Variable 'call' must be private and have accessor methods. 139
 Error design VisibilityModifier Variable 'priority' must be private and have accessor methods. 140
 Error design VisibilityModifier Variable 'span' must be private and have accessor methods. 141
 Error design VisibilityModifier Variable 'remoteId' must be private and have accessor methods. 158
 Error design VisibilityModifier Variable 'socket' must be private and have accessor methods. 159
 Error design VisibilityModifier Variable 'in' must be private and have accessor methods. 160
 Error design VisibilityModifier Variable 'out' must be private and have accessor methods. 161
 Error design VisibilityModifier Variable 'calls' must be private and have accessor methods. 174
 Error design VisibilityModifier Variable 'shouldCloseConnection' must be private and have accessor methods. 177
 Error design VisibilityModifier Variable 'callSender' must be private and have accessor methods. 178
 Error design VisibilityModifier Variable 'callsToWrite' must be private and have accessor methods. 200

org/apache/hadoop/hbase/ipc/RpcControllerFactory.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 43

org/apache/hadoop/hbase/ipc/RpcExecutor.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'currentQueueLimit' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'q' must be private and have accessor methods. 141
 Error design VisibilityModifier Variable 'handlerFailureThreshhold' must be private and have accessor methods. 143

org/apache/hadoop/hbase/ipc/RpcServer.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 86 - org.apache.hadoop.hbase.io.BoundedByteBufferPool. 89
 Error design VisibilityModifier Variable 'secretManager' must be private and have accessor methods. 197
 Error design VisibilityModifier Variable 'authManager' must be private and have accessor methods. 198
 Error design VisibilityModifier Variable 'bindAddress' must be private and have accessor methods. 209
 Error design VisibilityModifier Variable 'port' must be private and have accessor methods. 210
 Error design VisibilityModifier Variable 'maxIdleTime' must be private and have accessor methods. 212
 Error design VisibilityModifier Variable 'thresholdIdleConnections' must be private and have accessor methods. 215
 Error design VisibilityModifier Variable 'maxConnectionsToNuke' must be private and have accessor methods. 219
 Error design VisibilityModifier Variable 'metrics' must be private and have accessor methods. 223
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 225
 Error design VisibilityModifier Variable 'socketSendBufferSize' must be private and have accessor methods. 228
 Error design VisibilityModifier Variable 'tcpNoDelay' must be private and have accessor methods. 229
 Error design VisibilityModifier Variable 'tcpKeepAlive' must be private and have accessor methods. 230
 Error design VisibilityModifier Variable 'purgeTimeout' must be private and have accessor methods. 231
 Error design VisibilityModifier Variable 'running' must be private and have accessor methods. 238
 Error design VisibilityModifier Variable 'started' must be private and have accessor methods. 244
 Error design VisibilityModifier Variable 'callQueueSize' must be private and have accessor methods. 249
 Error design VisibilityModifier Variable 'connectionList' must be private and have accessor methods. 251
 Error design VisibilityModifier Variable 'responder' must be private and have accessor methods. 256
 Error design VisibilityModifier Variable 'authTokenSecretMgr' must be private and have accessor methods. 257
 Error design VisibilityModifier Variable 'numConnections' must be private and have accessor methods. 258
 Error design VisibilityModifier Variable 'errorHandler' must be private and have accessor methods. 260
 Error design VisibilityModifier Variable 'id' must be private and have accessor methods. 290
 Error design VisibilityModifier Variable 'service' must be private and have accessor methods. 291
 Error design VisibilityModifier Variable 'md' must be private and have accessor methods. 292
 Error design VisibilityModifier Variable 'header' must be private and have accessor methods. 293
 Error design VisibilityModifier Variable 'param' must be private and have accessor methods. 294
 Error design VisibilityModifier Variable 'cellScanner' must be private and have accessor methods. 296
 Error design VisibilityModifier Variable 'connection' must be private and have accessor methods. 297
 Error design VisibilityModifier Variable 'timestamp' must be private and have accessor methods. 298
 Error design VisibilityModifier Variable 'response' must be private and have accessor methods. 303
 Error design VisibilityModifier Variable 'delayResponse' must be private and have accessor methods. 304
 Error design VisibilityModifier Variable 'responder' must be private and have accessor methods. 305
 Error design VisibilityModifier Variable 'delayReturnValue' must be private and have accessor methods. 306
 Error design VisibilityModifier Variable 'size' must be private and have accessor methods. 308
 Error design VisibilityModifier Variable 'isError' must be private and have accessor methods. 309
 Error design VisibilityModifier Variable 'tinfo' must be private and have accessor methods. 310
 Error design VisibilityModifier Variable 'channel' must be private and have accessor methods. 1202
 Error design VisibilityModifier Variable 'responseQueue' must be private and have accessor methods. 1205
 Error design VisibilityModifier Variable 'socket' must be private and have accessor methods. 1210
 Error design VisibilityModifier Variable 'hostAddress' must be private and have accessor methods. 1213
 Error design VisibilityModifier Variable 'remotePort' must be private and have accessor methods. 1214
 Error design VisibilityModifier Variable 'connectionHeader' must be private and have accessor methods. 1215
 Error design VisibilityModifier Variable 'service' must be private and have accessor methods. 1224
 Error design VisibilityModifier Variable 'user' must be private and have accessor methods. 1225
 Error design VisibilityModifier Variable 'useSasl' must be private and have accessor methods. 1232
 Error design VisibilityModifier Variable 'saslServer' must be private and have accessor methods. 1233
 Error design VisibilityModifier Variable 'attemptingUser' must be private and have accessor methods. 1247
 Error misc ArrayTypeStyle Array brackets at illegal position. 1371
 Error blocks EmptyBlock Must have at least one statement. 1479
 Error blocks EmptyBlock Must have at least one statement. 1914
 Error blocks EmptyBlock Must have at least one statement. 1916
 Error blocks EmptyBlock Must have at least one statement. 1918
 Error sizes LineLength Line is longer than 100 characters (found 103). 2348
 Error sizes LineLength Line is longer than 100 characters (found 102). 2369

org/apache/hadoop/hbase/ipc/ServerRpcController.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 24 - org.apache.hadoop.util.StringUtils. 28
 Error imports RedundantImport Duplicate import to line 21 - java.io.IOException. 30

org/apache/hadoop/hbase/ipc/SimpleRpcScheduler.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 102). 220
 Error sizes LineLength Line is longer than 100 characters (found 101). 223
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 228

org/apache/hadoop/hbase/ipc/TimeLimitedRpcController.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'callTimeout' must be private and have accessor methods. 35
 Error design VisibilityModifier Variable 'cancelled' must be private and have accessor methods. 36
 Error design VisibilityModifier Variable 'cancellationCb' must be private and have accessor methods. 37
 Error design VisibilityModifier Variable 'failureCb' must be private and have accessor methods. 40

org/apache/hadoop/hbase/mapred/Driver.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 32

org/apache/hadoop/hbase/mapred/GroupingTableMap.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'columns' must be private and have accessor methods. 54

org/apache/hadoop/hbase/mapred/HRegionPartitioner.java

Severity Category Rule Message Line
 Error whitespace ParenPad ')' is preceded with whitespace. 86

org/apache/hadoop/hbase/mapred/TableInputFormat.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseConfiguration. 28

org/apache/hadoop/hbase/mapred/TableMapReduceUtil.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.conf.Configuration. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier. 36
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector. 37
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.zookeeper.ZKClusterId. 41
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher. 42
 Error imports UnusedImports Unused import - org.apache.hadoop.io.Text. 43
 Error imports UnusedImports Unused import - org.apache.hadoop.security.token.Token. 50
 Error imports UnusedImports Unused import - org.apache.zookeeper.KeeperException. 51
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 56
 Error sizes LineLength Line is longer than 100 characters (found 113). 332

org/apache/hadoop/hbase/mapreduce/CellCounter.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 70
 Error sizes LineLength Line is longer than 100 characters (found 101). 206
 Error misc ArrayTypeStyle Array brackets at illegal position. 222
 Error sizes LineLength Line is longer than 100 characters (found 104). 237
 Error sizes LineLength Line is longer than 100 characters (found 111). 284
 Error sizes LineLength Line is longer than 100 characters (found 114). 286

org/apache/hadoop/hbase/mapreduce/CellCreator.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 93

org/apache/hadoop/hbase/mapreduce/CopyTable.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'startTime' must be private and have accessor methods. 59
 Error design VisibilityModifier Variable 'endTime' must be private and have accessor methods. 60
 Error design VisibilityModifier Variable 'versions' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'tableName' must be private and have accessor methods. 62
 Error design VisibilityModifier Variable 'startRow' must be private and have accessor methods. 63
 Error design VisibilityModifier Variable 'stopRow' must be private and have accessor methods. 64
 Error design VisibilityModifier Variable 'dstTableName' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'peerAddress' must be private and have accessor methods. 66
 Error design VisibilityModifier Variable 'families' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'allCells' must be private and have accessor methods. 68
 Error design VisibilityModifier Variable 'shuffle' must be private and have accessor methods. 69
 Error design VisibilityModifier Variable 'bulkload' must be private and have accessor methods. 71
 Error design VisibilityModifier Variable 'bulkloadDir' must be private and have accessor methods. 72
 Error sizes LineLength Line is longer than 100 characters (found 113). 197
 Error sizes LineLength Line is longer than 100 characters (found 103). 209
 Error sizes LineLength Line is longer than 100 characters (found 106). 211
 Error sizes LineLength Line is longer than 100 characters (found 104). 212
 Error sizes LineLength Line is longer than 100 characters (found 106). 214
 Error sizes LineLength Line is longer than 100 characters (found 110). 217
 Error whitespace ParenPad ')' is preceded with whitespace. 303

org/apache/hadoop/hbase/mapreduce/Driver.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 32

org/apache/hadoop/hbase/mapreduce/Export.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 50
 Error sizes LineLength Line is longer than 100 characters (found 118). 81
 Error sizes LineLength Line is longer than 100 characters (found 101). 85
 Error sizes LineLength Line is longer than 100 characters (found 121). 158

org/apache/hadoop/hbase/mapreduce/GroupingTableMapper.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'columns' must be private and have accessor methods. 53

org/apache/hadoop/hbase/mapreduce/HFileInputFormat.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 74
 Error sizes LineLength Line is longer than 100 characters (found 106). 167

org/apache/hadoop/hbase/mapreduce/HFileOutputFormat.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'LOG' must be private and have accessor methods. 60

org/apache/hadoop/hbase/mapreduce/HFileOutputFormat2.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'LOG' must be private and have accessor methods. 89
 Error sizes MethodLength Method length is 168 lines (max allowed is 150). 117
 Error design VisibilityModifier Variable 'written' must be private and have accessor methods. 292
 Error design VisibilityModifier Variable 'writer' must be private and have accessor methods. 293
 Error whitespace MethodParamPad '(' should be on the previous line. 492

org/apache/hadoop/hbase/mapreduce/HLogInputFormat.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.wal.WAL. 26

org/apache/hadoop/hbase/mapreduce/HRegionPartitioner.java

Severity Category Rule Message Line
 Error whitespace ParenPad ')' is preceded with whitespace. 94

org/apache/hadoop/hbase/mapreduce/HashTable.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'tableHash' must be private and have accessor methods. 78
 Error design VisibilityModifier Variable 'destPath' must be private and have accessor methods. 79
 Error design VisibilityModifier Variable 'hashDir' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'tableName' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'families' must be private and have accessor methods. 90
 Error design VisibilityModifier Variable 'batchSize' must be private and have accessor methods. 91
 Error design VisibilityModifier Variable 'numHashFiles' must be private and have accessor methods. 92
 Error design VisibilityModifier Variable 'startRow' must be private and have accessor methods. 93
 Error design VisibilityModifier Variable 'stopRow' must be private and have accessor methods. 94
 Error design VisibilityModifier Variable 'scanBatch' must be private and have accessor methods. 95
 Error design VisibilityModifier Variable 'versions' must be private and have accessor methods. 96
 Error design VisibilityModifier Variable 'startTime' must be private and have accessor methods. 97
 Error design VisibilityModifier Variable 'endTime' must be private and have accessor methods. 98
 Error design VisibilityModifier Variable 'partitions' must be private and have accessor methods. 100

org/apache/hadoop/hbase/mapreduce/Import.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 33 - org.apache.hadoop.hbase.classification.InterfaceAudience. 44
 Error imports RedundantImport Duplicate import to line 34 - org.apache.hadoop.hbase.classification.InterfaceStability. 45
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 73

org/apache/hadoop/hbase/mapreduce/ImportTsv.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 480
 Error sizes LineLength Line is longer than 100 characters (found 113). 613
 Error sizes LineLength Line is longer than 100 characters (found 101). 615
 Error sizes LineLength Line is longer than 100 characters (found 107). 625
 Error sizes LineLength Line is longer than 100 characters (found 105). 635
 Error sizes LineLength Line is longer than 100 characters (found 103). 638
 Error sizes LineLength Line is longer than 100 characters (found 102). 639
 Error misc ArrayTypeStyle Array brackets at illegal position. 665
 Error sizes LineLength Line is longer than 100 characters (found 101). 708

org/apache/hadoop/hbase/mapreduce/IndexBuilder.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 127). 53
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 65

org/apache/hadoop/hbase/mapreduce/JarFinder.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 47

org/apache/hadoop/hbase/mapreduce/KeyValueSortReducer.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 118). 38
 Error sizes LineLength Line is longer than 100 characters (found 126). 40

org/apache/hadoop/hbase/mapreduce/LoadIncrementalHFiles.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.Collections. 30
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.backup.BackupType. 67
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.backup.impl.BackupManager. 68
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.backup.impl.BackupSystemTable. 69
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint. 101
 Error design VisibilityModifier Variable 'family' must be private and have accessor methods. 268
 Error design VisibilityModifier Variable 'hfilePath' must be private and have accessor methods. 269
 Error sizes LineLength Line is longer than 100 characters (found 117). 1191

org/apache/hadoop/hbase/mapreduce/MultiTableInputFormatBase.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 31 - org.apache.hadoop.hbase.TableName. 32
 Error design VisibilityModifier Variable 'LOG' must be private and have accessor methods. 62

org/apache/hadoop/hbase/mapreduce/MultiTableOutputFormat.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.HTable. 36
 Error design VisibilityModifier Variable 'connection' must be private and have accessor methods. 79
 Error design VisibilityModifier Variable 'mutatorMap' must be private and have accessor methods. 80
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 81
 Error design VisibilityModifier Variable 'useWriteAheadLogging' must be private and have accessor methods. 82

org/apache/hadoop/hbase/mapreduce/MultithreadedTableMapper.java

Severity Category Rule Message Line
 Error whitespace ParenPad '(' is followed by whitespace. 99
 Error sizes LineLength Line is longer than 100 characters (found 106). 263
 Error sizes LineLength Line is longer than 100 characters (found 107). 280

org/apache/hadoop/hbase/mapreduce/RowCounter.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 45

org/apache/hadoop/hbase/mapreduce/SampleUploader.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil. 28
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 60

org/apache/hadoop/hbase/mapreduce/SimpleTotalOrderPartitioner.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 53
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 55

org/apache/hadoop/hbase/mapreduce/SyncTable.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'sourceHashDir' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'sourceTableName' must be private and have accessor methods. 68
 Error design VisibilityModifier Variable 'targetTableName' must be private and have accessor methods. 69
 Error design VisibilityModifier Variable 'sourceZkCluster' must be private and have accessor methods. 71
 Error design VisibilityModifier Variable 'targetZkCluster' must be private and have accessor methods. 72
 Error design VisibilityModifier Variable 'dryRun' must be private and have accessor methods. 73
 Error design VisibilityModifier Variable 'counters' must be private and have accessor methods. 75
 Error design VisibilityModifier Variable 'sourceHashDir' must be private and have accessor methods. 157
 Error design VisibilityModifier Variable 'sourceConnection' must be private and have accessor methods. 159
 Error design VisibilityModifier Variable 'targetConnection' must be private and have accessor methods. 160
 Error design VisibilityModifier Variable 'sourceTable' must be private and have accessor methods. 161
 Error design VisibilityModifier Variable 'targetTable' must be private and have accessor methods. 162
 Error design VisibilityModifier Variable 'dryRun' must be private and have accessor methods. 163
 Error design VisibilityModifier Variable 'sourceTableHash' must be private and have accessor methods. 165
 Error design VisibilityModifier Variable 'sourceHashReader' must be private and have accessor methods. 166
 Error design VisibilityModifier Variable 'currentSourceHash' must be private and have accessor methods. 167
 Error design VisibilityModifier Variable 'nextSourceKey' must be private and have accessor methods. 168
 Error design VisibilityModifier Variable 'targetHasher' must be private and have accessor methods. 169
 Error design VisibilityModifier Variable 'mapperException' must be private and have accessor methods. 171

org/apache/hadoop/hbase/mapreduce/TableInputFormatBase.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'LOG' must be private and have accessor methods. 118
 Error whitespace ParenPad '(' is followed by whitespace. 275
 Error misc ArrayTypeStyle Array brackets at illegal position. 525
 Error sizes LineLength Line is longer than 100 characters (found 116). 538
 Error sizes LineLength Line is longer than 100 characters (found 127). 540
 Error sizes LineLength Line is longer than 100 characters (found 102). 637

org/apache/hadoop/hbase/mapreduce/TableMapReduceUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 68
 Error design VisibilityModifier Variable 'LOG' must be private and have accessor methods. 72
 Error sizes LineLength Line is longer than 100 characters (found 105). 596
 Error sizes LineLength Line is longer than 100 characters (found 105). 627
 Error sizes LineLength Line is longer than 100 characters (found 101). 872

org/apache/hadoop/hbase/mapreduce/TableOutputFormat.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.HTable. 36
 Error sizes LineLength Line is longer than 100 characters (found 127). 74

org/apache/hadoop/hbase/mapreduce/TableRecordReaderImpl.java

Severity Category Rule Message Line
 Error blocks EmptyBlock Must have at least one statement. 114

org/apache/hadoop/hbase/mapreduce/TableSnapshotInputFormatImpl.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 58

org/apache/hadoop/hbase/mapreduce/TableSplit.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'code' must be private and have accessor methods. 55

org/apache/hadoop/hbase/mapreduce/TextSortReducer.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 106). 163

org/apache/hadoop/hbase/mapreduce/TsvImporterMapper.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'ts' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'parser' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 63
 Error design VisibilityModifier Variable 'cellVisibilityExpr' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'ttl' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'kvCreator' must be private and have accessor methods. 69
 Error sizes LineLength Line is longer than 100 characters (found 102). 159

org/apache/hadoop/hbase/mapreduce/WALInputFormat.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.wal.WAL. 36
 Error design VisibilityModifier Variable 'currentEntry' must be private and have accessor methods. 141
 Error sizes LineLength Line is longer than 100 characters (found 103). 258

org/apache/hadoop/hbase/mapreduce/WALPlayer.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 120
 Error blocks EmptyBlock Must have at least one statement. 221

org/apache/hadoop/hbase/mapreduce/replication/VerifyReplication.java

Severity Category Rule Message Line
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - org.apache.hadoop.hbase.*. 27
 Error design VisibilityModifier Variable 'startTime' must be private and have accessor methods. 72
 Error design VisibilityModifier Variable 'endTime' must be private and have accessor methods. 73
 Error design VisibilityModifier Variable 'versions' must be private and have accessor methods. 74
 Error design VisibilityModifier Variable 'tableName' must be private and have accessor methods. 75
 Error design VisibilityModifier Variable 'families' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'peerId' must be private and have accessor methods. 77
 Error sizes LineLength Line is longer than 100 characters (found 119). 371
 Error sizes LineLength Line is longer than 100 characters (found 106). 375

org/apache/hadoop/hbase/master/ActiveMasterManager.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'clusterHasActiveMaster' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'clusterShutDown' must be private and have accessor methods. 56
 Error sizes LineLength Line is longer than 100 characters (found 104). 209

org/apache/hadoop/hbase/master/AssignmentManager.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 101). 134
 Error design VisibilityModifier Variable 'server' must be private and have accessor methods. 141
 Error design VisibilityModifier Variable 'replicasToClose' must be private and have accessor methods. 157
 Error sizes LineLength Line is longer than 100 characters (found 103). 181
 Error design VisibilityModifier Variable 'regionPlans' must be private and have accessor methods. 190
 Error design VisibilityModifier Variable 'failoverCleanupDone' must be private and have accessor methods. 235
 Error design VisibilityModifier Variable 'TEST_SKIP_SPLIT_HANDLING' must be private and have accessor methods. 258
 Error whitespace MethodParamPad '(' should be on the previous line. 294
 Error whitespace MethodParamPad '(' is preceded with whitespace. 294
 Error misc UpperEll Should use uppercase 'L'. 313
 Error sizes MethodLength Method length is 198 lines (max allowed is 150). 938
 Error sizes LineLength Line is longer than 100 characters (found 107). 1104
 Error sizes MethodLength Method length is 208 lines (max allowed is 150). 1622
 Error sizes LineLength Line is longer than 100 characters (found 102). 1828
 Error sizes MethodLength Method length is 247 lines (max allowed is 150). 2070
 Error sizes LineLength Line is longer than 100 characters (found 105). 2128
 Error sizes LineLength Line is longer than 100 characters (found 102). 2315
 Error sizes LineLength Line is longer than 100 characters (found 105). 2402
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 3961
 Error sizes LineLength Line is longer than 100 characters (found 116). 4163
 Error coding InnerAssignment Inner assignments should be avoided. 4322

org/apache/hadoop/hbase/master/AssignmentVerificationReport.java

Severity Category Rule Message Line
 Error sizes MethodLength Method length is 222 lines (max allowed is 150). 97
 Error whitespace ParenPad '(' is followed by whitespace. 466

org/apache/hadoop/hbase/master/BulkAssigner.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'server' must be private and have accessor methods. 40

org/apache/hadoop/hbase/master/CatalogJanitor.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 103). 134
 Error sizes LineLength Line is longer than 100 characters (found 102). 149
 Error sizes LineLength Line is longer than 100 characters (found 103). 287
 Error design VisibilityModifier Variable 'rowEndKeyComparator' must be private and have accessor methods. 313
 Error coding InnerAssignment Inner assignments should be avoided. 426

org/apache/hadoop/hbase/master/ClusterStatusPublisher.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 108). 299
 Error design FinalClass Class ClusterStatusEncoder should be declared as final. 325

org/apache/hadoop/hbase/master/GeneralBulkAssigner.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'bulkPlan' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'assignmentManager' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'waitTillAllAssigned' must be private and have accessor methods. 52

org/apache/hadoop/hbase/master/HMaster.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - com.google.common.cache.Cache. 22
 Error imports UnusedImports Unused import - com.google.common.cache.CacheBuilder. 23
 Error design VisibilityModifier Variable 'regionServerTracker' must be private and have accessor methods. 287
 Error design VisibilityModifier Variable 'loadBalancerTracker' must be private and have accessor methods. 291
 Error design VisibilityModifier Variable 'metricsMaster' must be private and have accessor methods. 306
 Error design VisibilityModifier Variable 'serverManager' must be private and have accessor methods. 311
 Error design VisibilityModifier Variable 'assignmentManager' must be private and have accessor methods. 314
 Error design VisibilityModifier Variable 'rsFatals' must be private and have accessor methods. 319
 Error design VisibilityModifier Variable 'initialized' must be private and have accessor methods. 326
 Error design VisibilityModifier Variable 'serviceStarted' must be private and have accessor methods. 330
 Error design VisibilityModifier Variable 'balancer' must be private and have accessor methods. 335
 Error design VisibilityModifier Variable 'catalogJanitorChore' must be private and have accessor methods. 343
 Error design VisibilityModifier Variable 'cpHost' must be private and have accessor methods. 355
 Error design VisibilityModifier Variable 'coprocessorServiceHandlers' must be private and have accessor methods. 376
 Error design VisibilityModifier Variable 'snapshotManager' must be private and have accessor methods. 379
 Error sizes MethodLength Method length is 231 lines (max allowed is 150). 723
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 1131
 Error sizes LineLength Line is longer than 100 characters (found 107). 1557
 Error sizes LineLength Line is longer than 100 characters (found 105). 1674
 Error sizes LineLength Line is longer than 100 characters (found 105). 1676
 Error sizes LineLength Line is longer than 100 characters (found 102). 2161
 Error sizes LineLength Line is longer than 100 characters (found 102). 2508
 Error sizes LineLength Line is longer than 100 characters (found 104). 2779
 Error whitespace ParenPad ')' is preceded with whitespace. 3136
 Error sizes LineLength Line is longer than 100 characters (found 102). 3213

org/apache/hadoop/hbase/master/HMasterCommandLine.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 77

org/apache/hadoop/hbase/master/MasterCoprocessorHost.java

Severity Category Rule Message Line
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - org.apache.hadoop.hbase.coprocessor.*. 41
 Error design VisibilityModifier Variable 'supportGroupCPs' must be private and have accessor methods. 65
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 917
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 929

org/apache/hadoop/hbase/master/MasterFileSystem.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 79
 Error design VisibilityModifier Variable 'master' must be private and have accessor methods. 81
 Error design VisibilityModifier Variable 'splitLogLock' must be private and have accessor methods. 100
 Error design VisibilityModifier Variable 'distributedLogReplay' must be private and have accessor methods. 101
 Error design VisibilityModifier Variable 'splitLogManager' must be private and have accessor methods. 102
 Error sizes LineLength Line is longer than 100 characters (found 102). 165
 Error sizes LineLength Line is longer than 100 characters (found 110). 483
 Error sizes LineLength Line is longer than 100 characters (found 102). 491
 Error sizes LineLength Line is longer than 100 characters (found 104). 495
 Error sizes LineLength Line is longer than 100 characters (found 110). 507
 Error sizes LineLength Line is longer than 100 characters (found 109). 525
 Error sizes LineLength Line is longer than 100 characters (found 101). 630

org/apache/hadoop/hbase/master/MasterRpcServices.java

Severity Category Rule Message Line
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - org.apache.hadoop.hbase.protobuf.generated.*. 60
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.AccessDeniedException. 203
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.User. 204
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.access.AccessController. 205
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.visibility.VisibilityController. 206

org/apache/hadoop/hbase/master/MasterServices.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.concurrent.Future. 23

org/apache/hadoop/hbase/master/MetricsAssignmentManagerSourceImpl.java

Severity Category Rule Message Line
 Error misc UpperEll Should use uppercase 'L'. 48
 Error misc UpperEll Should use uppercase 'L'. 49
 Error misc UpperEll Should use uppercase 'L'. 50

org/apache/hadoop/hbase/master/MetricsMaster.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 117). 43
 Error sizes LineLength Line is longer than 100 characters (found 114). 45
 Error sizes LineLength Line is longer than 100 characters (found 115). 47

org/apache/hadoop/hbase/master/MetricsMasterProcSource.java

Severity Category Rule Message Line
 Error design InterfaceIsType interfaces should describe a type and hence have methods. 26

org/apache/hadoop/hbase/master/MetricsMasterQuotaSourceImpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 102). 35

org/apache/hadoop/hbase/master/MetricsMasterSourceFactoryImpl.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'masterSource' must be private and have accessor methods. 30

org/apache/hadoop/hbase/master/MetricsMasterSourceImpl.java

Severity Category Rule Message Line
 Error misc UpperEll Should use uppercase 'L'. 61

org/apache/hadoop/hbase/master/RegionPlacementMaintainer.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 101). 120
 Error sizes MethodLength Method length is 260 lines (max allowed is 150). 193
 Error whitespace ParenPad ')' is preceded with whitespace. 474
 Error whitespace ParenPad ')' is preceded with whitespace. 490
 Error whitespace ParenPad ')' is preceded with whitespace. 624
 Error whitespace ParenPad ')' is preceded with whitespace. 718
 Error whitespace ParenPad '(' is followed by whitespace. 835
 Error sizes MethodLength Method length is 169 lines (max allowed is 150). 948
 Error misc ArrayTypeStyle Array brackets at illegal position. 948

org/apache/hadoop/hbase/master/RegionState.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 103). 382

org/apache/hadoop/hbase/master/RegionStateStore.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 103). 245
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 261

org/apache/hadoop/hbase/master/RegionStates.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 40 - org.apache.hadoop.hbase.MetaTableAccessor. 47
 Error design VisibilityModifier Variable 'regionsInTransition' must be private and have accessor methods. 73

org/apache/hadoop/hbase/master/ServerManager.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ZooKeeperConnectionException. 49
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.RetriesExhaustedException. 53
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.Threads. 77
 Error blocks EmptyBlock Must have at least one statement. 571

org/apache/hadoop/hbase/master/SplitLogManager.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.wal.WALFactory. 65
 Error design VisibilityModifier Variable 'recoveringRegionLock' must be private and have accessor methods. 120
 Error design VisibilityModifier Variable 'installed' must be private and have accessor methods. 625
 Error design VisibilityModifier Variable 'done' must be private and have accessor methods. 626
 Error design VisibilityModifier Variable 'error' must be private and have accessor methods. 627
 Error design VisibilityModifier Variable 'isDead' must be private and have accessor methods. 628
 Error design VisibilityModifier Variable 'last_update' must be private and have accessor methods. 641
 Error design VisibilityModifier Variable 'last_version' must be private and have accessor methods. 642
 Error design VisibilityModifier Variable 'cur_worker_name' must be private and have accessor methods. 643
 Error design VisibilityModifier Variable 'batch' must be private and have accessor methods. 644
 Error design VisibilityModifier Variable 'status' must be private and have accessor methods. 645
 Error design VisibilityModifier Variable 'incarnation' must be private and have accessor methods. 646
 Error design VisibilityModifier Variable 'unforcedResubmits' must be private and have accessor methods. 647
 Error design VisibilityModifier Variable 'resubmitThresholdReached' must be private and have accessor methods. 648
 Error design VisibilityModifier Variable 'statusMsg' must be private and have accessor methods. 824

org/apache/hadoop/hbase/master/TableLockManager.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.Bytes. 38
 Error sizes LineLength Line is longer than 100 characters (found 119). 167
 Error design VisibilityModifier Variable 'lockTimeoutMs' must be private and have accessor methods. 251
 Error design VisibilityModifier Variable 'tableName' must be private and have accessor methods. 252
 Error design VisibilityModifier Variable 'lock' must be private and have accessor methods. 253
 Error design VisibilityModifier Variable 'isShared' must be private and have accessor methods. 254
 Error design VisibilityModifier Variable 'zkWatcher' must be private and have accessor methods. 255
 Error design VisibilityModifier Variable 'serverName' must be private and have accessor methods. 256
 Error design VisibilityModifier Variable 'purpose' must be private and have accessor methods. 257
 Error sizes LineLength Line is longer than 100 characters (found 105). 359

org/apache/hadoop/hbase/master/TableNamespaceManager.java

Severity Category Rule Message Line
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 103
 Error sizes LineLength Line is longer than 100 characters (found 105). 237

org/apache/hadoop/hbase/master/balancer/BaseLoadBalancer.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'regionFinder' must be private and have accessor methods. 73
 Error design VisibilityModifier Variable 'servers' must be private and have accessor methods. 108
 Error sizes LineLength Line is longer than 100 characters (found 107). 109
 Error design VisibilityModifier Variable 'hosts' must be private and have accessor methods. 109
 Error design VisibilityModifier Variable 'racks' must be private and have accessor methods. 110
 Error design VisibilityModifier Variable 'multiServersPerHost' must be private and have accessor methods. 111
 Error design VisibilityModifier Variable 'tables' must be private and have accessor methods. 113
 Error design VisibilityModifier Variable 'regions' must be private and have accessor methods. 114
 Error design VisibilityModifier Variable 'regionLoads' must be private and have accessor methods. 115
 Error design VisibilityModifier Variable 'regionLocations' must be private and have accessor methods. 118
 Error design VisibilityModifier Variable 'serverIndexToHostIndex' must be private and have accessor methods. 120
 Error design VisibilityModifier Variable 'serverIndexToRackIndex' must be private and have accessor methods. 121
 Error design VisibilityModifier Variable 'regionsPerServer' must be private and have accessor methods. 123
 Error design VisibilityModifier Variable 'regionsPerHost' must be private and have accessor methods. 124
 Error design VisibilityModifier Variable 'regionsPerRack' must be private and have accessor methods. 125
 Error sizes LineLength Line is longer than 100 characters (found 104). 126
 Error design VisibilityModifier Variable 'primariesOfRegionsPerServer' must be private and have accessor methods. 126
 Error sizes LineLength Line is longer than 100 characters (found 102). 127
 Error design VisibilityModifier Variable 'primariesOfRegionsPerHost' must be private and have accessor methods. 127
 Error sizes LineLength Line is longer than 100 characters (found 102). 128
 Error design VisibilityModifier Variable 'primariesOfRegionsPerRack' must be private and have accessor methods. 128
 Error design VisibilityModifier Variable 'serversPerHost' must be private and have accessor methods. 130
 Error design VisibilityModifier Variable 'serversPerRack' must be private and have accessor methods. 131
 Error design VisibilityModifier Variable 'regionIndexToServerIndex' must be private and have accessor methods. 132
 Error design VisibilityModifier Variable 'initialRegionIndexToServerIndex' must be private and have accessor methods. 133
 Error design VisibilityModifier Variable 'regionIndexToTableIndex' must be private and have accessor methods. 134
 Error design VisibilityModifier Variable 'numRegionsPerServerPerTable' must be private and have accessor methods. 135
 Error design VisibilityModifier Variable 'numMaxRegionsPerTable' must be private and have accessor methods. 136
 Error design VisibilityModifier Variable 'regionIndexToPrimaryIndex' must be private and have accessor methods. 137
 Error design VisibilityModifier Variable 'hasRegionReplicas' must be private and have accessor methods. 138
 Error design VisibilityModifier Variable 'serverIndicesSortedByRegionCount' must be private and have accessor methods. 140
 Error design VisibilityModifier Variable 'serverIndicesSortedByLocality' must be private and have accessor methods. 141
 Error design VisibilityModifier Variable 'serversToIndex' must be private and have accessor methods. 143
 Error design VisibilityModifier Variable 'hostsToIndex' must be private and have accessor methods. 144
 Error design VisibilityModifier Variable 'racksToIndex' must be private and have accessor methods. 145
 Error design VisibilityModifier Variable 'tablesToIndex' must be private and have accessor methods. 146
 Error design VisibilityModifier Variable 'regionsToIndex' must be private and have accessor methods. 147
 Error design VisibilityModifier Variable 'localityPerServer' must be private and have accessor methods. 148
 Error design VisibilityModifier Variable 'numServers' must be private and have accessor methods. 150
 Error design VisibilityModifier Variable 'numHosts' must be private and have accessor methods. 151
 Error design VisibilityModifier Variable 'numRacks' must be private and have accessor methods. 152
 Error design VisibilityModifier Variable 'numTables' must be private and have accessor methods. 153
 Error design VisibilityModifier Variable 'numRegions' must be private and have accessor methods. 154
 Error design VisibilityModifier Variable 'numMovedRegions' must be private and have accessor methods. 156
 Error design VisibilityModifier Variable 'clusterState' must be private and have accessor methods. 157
 Error design VisibilityModifier Variable 'rackManager' must be private and have accessor methods. 159
 Error sizes MethodLength Method length is 250 lines (max allowed is 150). 173
 Error sizes LineLength Line is longer than 100 characters (found 114). 271
 Error sizes LineLength Line is longer than 100 characters (found 107). 345
 Error sizes LineLength Line is longer than 100 characters (found 105). 346
 Error sizes LineLength Line is longer than 100 characters (found 101). 347
 Error design VisibilityModifier Variable 'type' must be private and have accessor methods. 599
 Error whitespace MethodParamPad '(' is preceded with whitespace. 600
 Error design VisibilityModifier Variable 'region' must be private and have accessor methods. 608
 Error design VisibilityModifier Variable 'server' must be private and have accessor methods. 609
 Error design VisibilityModifier Variable 'region' must be private and have accessor methods. 628
 Error design VisibilityModifier Variable 'fromServer' must be private and have accessor methods. 629
 Error design VisibilityModifier Variable 'toServer' must be private and have accessor methods. 630
 Error whitespace MethodParamPad '(' is preceded with whitespace. 640
 Error design VisibilityModifier Variable 'fromServer' must be private and have accessor methods. 649
 Error design VisibilityModifier Variable 'fromRegion' must be private and have accessor methods. 650
 Error design VisibilityModifier Variable 'toServer' must be private and have accessor methods. 651
 Error design VisibilityModifier Variable 'toRegion' must be private and have accessor methods. 652
 Error whitespace MethodParamPad '(' is preceded with whitespace. 662
 Error sizes LineLength Line is longer than 100 characters (found 102). 684
 Error sizes LineLength Line is longer than 100 characters (found 113). 690
 Error sizes LineLength Line is longer than 100 characters (found 109). 691
 Error sizes LineLength Line is longer than 100 characters (found 103). 709
 Error sizes LineLength Line is longer than 100 characters (found 113). 730
 Error sizes LineLength Line is longer than 100 characters (found 101). 787
 Error sizes LineLength Line is longer than 100 characters (found 105). 788
 Error sizes LineLength Line is longer than 100 characters (found 101). 789
 Error sizes LineLength Line is longer than 100 characters (found 108). 809
 Error sizes LineLength Line is longer than 100 characters (found 108). 824
 Error design VisibilityModifier Variable 'slop' must be private and have accessor methods. 1073
 Error design VisibilityModifier Variable 'config' must be private and have accessor methods. 1074
 Error design VisibilityModifier Variable 'rackManager' must be private and have accessor methods. 1075
 Error design VisibilityModifier Variable 'tablesOnMaster' must be private and have accessor methods. 1082
 Error design VisibilityModifier Variable 'metricsBalancer' must be private and have accessor methods. 1083
 Error design VisibilityModifier Variable 'clusterStatus' must be private and have accessor methods. 1084
 Error design VisibilityModifier Variable 'masterServerName' must be private and have accessor methods. 1085
 Error design VisibilityModifier Variable 'services' must be private and have accessor methods. 1086

org/apache/hadoop/hbase/master/balancer/FavoredNodeLoadBalancer.java

Severity Category Rule Message Line
 Error coding InnerAssignment Inner assignments should be avoided. 305

org/apache/hadoop/hbase/master/balancer/LoadBalancerFactory.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 29

org/apache/hadoop/hbase/master/balancer/RegionLocationFinder.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 102). 68

org/apache/hadoop/hbase/master/balancer/SimpleLoadBalancer.java

Severity Category Rule Message Line
 Error sizes MethodLength Method length is 240 lines (max allowed is 150). 184

org/apache/hadoop/hbase/master/balancer/StochasticLoadBalancer.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HTableDescriptor. 41
 Error design VisibilityModifier Variable 'loads' must be private and have accessor methods. 118
 Error sizes LineLength Line is longer than 100 characters (found 107). 731
 Error sizes LineLength Line is longer than 100 characters (found 109). 747
 Error sizes LineLength Line is longer than 100 characters (found 116). 761
 Error sizes LineLength Line is longer than 100 characters (found 114). 765
 Error design VisibilityModifier Variable 'randomGenerator' must be private and have accessor methods. 790
 Error design VisibilityModifier Variable 'cluster' must be private and have accessor methods. 908
 Error sizes LineLength Line is longer than 100 characters (found 106). 1228
 Error sizes LineLength Line is longer than 100 characters (found 106). 1229
 Error sizes LineLength Line is longer than 100 characters (found 109). 1233
 Error sizes LineLength Line is longer than 100 characters (found 109). 1276
 Error design VisibilityModifier Variable 'maxCost' must be private and have accessor methods. 1422
 Error design VisibilityModifier Variable 'costsPerGroup' must be private and have accessor methods. 1423
 Error design VisibilityModifier Variable 'primariesOfRegionsPerGroup' must be private and have accessor methods. 1424

org/apache/hadoop/hbase/master/cleaner/BaseLogCleanerDelegate.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 53

org/apache/hadoop/hbase/master/cleaner/CleanerChore.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.Map. 27
 Error imports UnusedImports Unused import - java.util.concurrent.atomic.AtomicBoolean. 28
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'cleanersChain' must be private and have accessor methods. 57
 Error design VisibilityModifier Variable 'directorySpaces' must be private and have accessor methods. 147

org/apache/hadoop/hbase/master/cleaner/HFileCleaner.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'largeFileQueue' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'smallFileQueue' must be private and have accessor methods. 77
 Error coding EmptyStatement Empty statement. 272
 Error design VisibilityModifier Variable 'done' must be private and have accessor methods. 312
 Error design VisibilityModifier Variable 'result' must be private and have accessor methods. 313
 Error design VisibilityModifier Variable 'filePath' must be private and have accessor methods. 314
 Error design VisibilityModifier Variable 'fileLength' must be private and have accessor methods. 315

org/apache/hadoop/hbase/master/handler/ClosedRegionHandler.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.master.RegionState. 29

org/apache/hadoop/hbase/master/handler/CreateTableHandler.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'fileSystemManager' must be private and have accessor methods. 66
 Error design VisibilityModifier Variable 'hTableDescriptor' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 68

org/apache/hadoop/hbase/master/handler/DeleteTableHandler.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'hTableDescriptor' must be private and have accessor methods. 57

org/apache/hadoop/hbase/master/handler/LogReplayHandler.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'master' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'services' must be private and have accessor methods. 46
 Error design VisibilityModifier Variable 'deadServers' must be private and have accessor methods. 47

org/apache/hadoop/hbase/master/handler/ServerShutdownHandler.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'serverName' must be private and have accessor methods. 64
 Error design VisibilityModifier Variable 'services' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'deadServers' must be private and have accessor methods. 66
 Error design VisibilityModifier Variable 'shouldSplitWal' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'regionAssignmentWaitTimeout' must be private and have accessor methods. 68
 Error sizes MethodLength Method length is 257 lines (max allowed is 150). 114
 Error sizes LineLength Line is longer than 100 characters (found 102). 263
 Error sizes LineLength Line is longer than 100 characters (found 102). 276

org/apache/hadoop/hbase/master/handler/TableEventHandler.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'masterServices' must be private and have accessor methods. 66
 Error design VisibilityModifier Variable 'tableName' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'tableLock' must be private and have accessor methods. 68
 Error whitespace ParenPad ')' is preceded with whitespace. 99

org/apache/hadoop/hbase/master/normalizer/SimpleRegionNormalizer.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.master.normalizer.NormalizationPlan. 30

org/apache/hadoop/hbase/master/procedure/DeleteTableProcedure.java

Severity Category Rule Message Line
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - org.apache.hadoop.hbase.*. 30

org/apache/hadoop/hbase/master/procedure/DisableTableProcedure.java

Severity Category Rule Message Line
 Error blocks EmptyBlock Must have at least one statement. 325

org/apache/hadoop/hbase/master/procedure/MasterProcedureEnv.java

Severity Category Rule Message Line
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 130

org/apache/hadoop/hbase/master/procedure/MasterProcedureUtil.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.User. 39

org/apache/hadoop/hbase/master/snapshot/CloneSnapshotHandler.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 104). 101

org/apache/hadoop/hbase/master/snapshot/DisabledTableSnapshotHandler.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HConstants. 28
 Error imports UnusedImports Unused import - org.apache.hadoop.conf.Configuration. 29
 Error imports RedundantImport Duplicate import to line 28 - org.apache.hadoop.hbase.HConstants. 30
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HConstants. 30

org/apache/hadoop/hbase/master/snapshot/MasterSnapshotVerifier.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 102). 91

org/apache/hadoop/hbase/master/snapshot/SnapshotFileCache.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 101). 131
 Error blocks EmptyBlock Must have at least one statement. 236
 Error design VisibilityModifier Variable 'lastModified' must be private and have accessor methods. 341
 Error design VisibilityModifier Variable 'files' must be private and have accessor methods. 342

org/apache/hadoop/hbase/master/snapshot/SnapshotManager.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 110). 271
 Error sizes LineLength Line is longer than 100 characters (found 102). 382
 Error sizes LineLength Line is longer than 100 characters (found 103). 679

org/apache/hadoop/hbase/master/snapshot/TakeSnapshotHandler.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 103). 63
 Error design VisibilityModifier Variable 'master' must be private and have accessor methods. 75
 Error design VisibilityModifier Variable 'metricsSnapshot' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'snapshot' must be private and have accessor methods. 77
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 78
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 79
 Error design VisibilityModifier Variable 'rootDir' must be private and have accessor methods. 80
 Error design VisibilityModifier Variable 'workingDir' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'monitor' must be private and have accessor methods. 84
 Error design VisibilityModifier Variable 'tableLockManager' must be private and have accessor methods. 85
 Error design VisibilityModifier Variable 'tableLock' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'status' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'snapshotTable' must be private and have accessor methods. 88
 Error design VisibilityModifier Variable 'snapshotManifest' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'htd' must be private and have accessor methods. 91

org/apache/hadoop/hbase/metrics/BaseSourceImpl.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'metricsRegistry' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'metricsName' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'metricsDescription' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'metricsContext' must be private and have accessor methods. 56
 Error design VisibilityModifier Variable 'metricsJmxContext' must be private and have accessor methods. 57
 Error misc UpperEll Should use uppercase 'L'. 101
 Error misc UpperEll Should use uppercase 'L'. 112
 Error misc UpperEll Should use uppercase 'L'. 123

org/apache/hadoop/hbase/migration/NamespaceUpgrade.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 83

org/apache/hadoop/hbase/migration/UpgradeTo96.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 103). 75

org/apache/hadoop/hbase/mob/DefaultMobStoreCompactor.java

Severity Category Rule Message Line
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - org.apache.hadoop.hbase.regionserver.*. 37
 Error sizes MethodLength Method length is 159 lines (max allowed is 150). 158

org/apache/hadoop/hbase/mob/DefaultMobStoreFlusher.java

Severity Category Rule Message Line
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - org.apache.hadoop.hbase.regionserver.*. 37

org/apache/hadoop/hbase/mob/MobConstants.java

Severity Category Rule Message Line
 Error design FinalClass Class MobConstants should be declared as final. 31
 Error misc UpperEll Should use uppercase 'L'. 73

org/apache/hadoop/hbase/mob/MobFileCache.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'lru' must be private and have accessor methods. 60

org/apache/hadoop/hbase/mob/MobFileName.java

Severity Category Rule Message Line
 Error design FinalClass Class MobFileName should be declared as final. 42

org/apache/hadoop/hbase/mob/MobUtils.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.CellComparator. 47
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 84
 Error sizes LineLength Line is longer than 100 characters (found 101). 869

org/apache/hadoop/hbase/mob/compactions/MobCompactionRequest.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'selectionTime' must be private and have accessor methods. 29
 Error design VisibilityModifier Variable 'type' must be private and have accessor methods. 30

org/apache/hadoop/hbase/mob/compactions/MobCompactor.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 42
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 43
 Error design VisibilityModifier Variable 'tableName' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'column' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'mobTableDir' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'mobFamilyDir' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'pool' must be private and have accessor methods. 49

org/apache/hadoop/hbase/mob/compactions/PartitionedMobCompactionRequest.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'delFiles' must be private and have accessor methods. 39
 Error design VisibilityModifier Variable 'compactionPartitions' must be private and have accessor methods. 40
 Error whitespace MethodParamPad '(' is preceded with whitespace. 89

org/apache/hadoop/hbase/mob/compactions/PartitionedMobCompactor.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'mergeableSize' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'delFileMaxCount' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'compactionBatchSize' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'compactionKVMax' must be private and have accessor methods. 90
 Error sizes LineLength Line is longer than 100 characters (found 103). 486

org/apache/hadoop/hbase/monitoring/MemoryBoundedLogMessageBuffer.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'message' must be private and have accessor methods. 96
 Error design VisibilityModifier Variable 'timestamp' must be private and have accessor methods. 97

org/apache/hadoop/hbase/monitoring/MonitoredTaskImpl.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'state' must be private and have accessor methods. 37

org/apache/hadoop/hbase/package-info.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 199). 5

org/apache/hadoop/hbase/procedure/Procedure.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'acquiredBarrierLatch' must be private and have accessor methods. 85
 Error design VisibilityModifier Variable 'releasedBarrierLatch' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'completedLatch' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'wakeFrequency' must be private and have accessor methods. 98
 Error design VisibilityModifier Variable 'timeoutInjector' must be private and have accessor methods. 99
 Error sizes LineLength Line is longer than 100 characters (found 102). 250
 Error sizes LineLength Line is longer than 100 characters (found 104). 306
 Error sizes LineLength Line is longer than 100 characters (found 106). 357

org/apache/hadoop/hbase/procedure/ProcedureCoordinator.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 103). 180

org/apache/hadoop/hbase/procedure/ProcedureManagerHost.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'procedures' must be private and have accessor methods. 49

org/apache/hadoop/hbase/procedure/ProcedureMemberRpcs.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 101). 55

org/apache/hadoop/hbase/procedure/RegionServerProcedureManager.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.zookeeper.KeeperException. 25

org/apache/hadoop/hbase/procedure/Subprocedure.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'monitor' must be private and have accessor methods. 72
 Error design VisibilityModifier Variable 'wakeFrequency' must be private and have accessor methods. 74
 Error design VisibilityModifier Variable 'executionTimeoutTimer' must be private and have accessor methods. 75
 Error design VisibilityModifier Variable 'rpcs' must be private and have accessor methods. 76

org/apache/hadoop/hbase/procedure/ZKProcedureCoordinatorRpcs.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'coordinator' must be private and have accessor methods. 43
 Error design VisibilityModifier Variable 'watcher' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'procedureType' must be private and have accessor methods. 46
 Error design VisibilityModifier Variable 'coordName' must be private and have accessor methods. 47
 Error sizes LineLength Line is longer than 100 characters (found 101). 209
 Error sizes LineLength Line is longer than 100 characters (found 110). 285

org/apache/hadoop/hbase/procedure/ZKProcedureMemberRpcs.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'member' must be private and have accessor methods. 60
 Error whitespace ParenPad ')' is preceded with whitespace. 219

org/apache/hadoop/hbase/procedure/ZKProcedureUtil.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'baseZNode' must be private and have accessor methods. 60
 Error design VisibilityModifier Variable 'acquiredZnode' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'reachedZnode' must be private and have accessor methods. 62
 Error design VisibilityModifier Variable 'abortZnode' must be private and have accessor methods. 63

org/apache/hadoop/hbase/procedure/flush/FlushTableSubprocedure.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'region' must be private and have accessor methods. 57

org/apache/hadoop/hbase/procedure/flush/RegionServerFlushTableProcedureManager.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.zookeeper.KeeperException. 53
 Error blocks EmptyBlock Must have at least one statement. 296

org/apache/hadoop/hbase/procedure2/ProcedureExecutor.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'testing' must be private and have accessor methods. 80
 Error design VisibilityModifier Variable 'killBeforeStoreUpdate' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'toggleKillBeforeStoreUpdate' must be private and have accessor methods. 83

org/apache/hadoop/hbase/procedure2/store/ProcedureStore.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ProcedureInfo. 26

org/apache/hadoop/hbase/procedure2/store/wal/ProcedureWALFormatReader.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ProcedureInfo. 31

org/apache/hadoop/hbase/protobuf/ProtobufUtil.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.RPCProtos. 87
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.User. 158
 Error sizes LineLength Line is longer than 100 characters (found 101). 182
 Error sizes LineLength Line is longer than 100 characters (found 101). 1634
 Error sizes LineLength Line is longer than 100 characters (found 105). 1962
 Error misc ArrayTypeStyle Array brackets at illegal position. 2029
 Error misc ArrayTypeStyle Array brackets at illegal position. 2049
 Error misc ArrayTypeStyle Array brackets at illegal position. 2064
 Error coding MissingSwitchDefault switch without "default" clause. 2097
 Error coding MissingSwitchDefault switch without "default" clause. 2120
 Error blocks EmptyBlock Must have at least one statement. 2494
 Error coding MissingSwitchDefault switch without "default" clause. 3083
 Error coding MissingSwitchDefault switch without "default" clause. 3100

org/apache/hadoop/hbase/protobuf/ReplicationProtbufUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 51

org/apache/hadoop/hbase/protobuf/RequestConverter.java

Severity Category Rule Message Line
 Error whitespace ParenPad '(' is followed by whitespace. 903
 Error whitespace ParenPad ')' is preceded with whitespace. 903

org/apache/hadoop/hbase/protobuf/ResponseConverter.java

Severity Category Rule Message Line
 Error whitespace MethodParamPad '(' should be on the previous line. 212
 Error whitespace MethodParamPad '(' should be on the previous line. 242
 Error sizes LineLength Line is longer than 100 characters (found 101). 353

org/apache/hadoop/hbase/quotas/FileSystemUtilizationChore.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.HRegion. 32
 Error sizes LineLength Line is longer than 100 characters (found 119). 39
 Error sizes LineLength Line is longer than 100 characters (found 112). 44
 Error sizes LineLength Line is longer than 100 characters (found 110). 47
 Error sizes LineLength Line is longer than 100 characters (found 116). 50
 Error sizes LineLength Line is longer than 100 characters (found 136). 53

org/apache/hadoop/hbase/quotas/NamespaceQuotaSnapshotStore.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 116). 49

org/apache/hadoop/hbase/quotas/NoopQuotaLimiter.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.quotas.OperationQuota.OperationType. 16

org/apache/hadoop/hbase/quotas/QuotaLimiter.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.quotas.OperationQuota.OperationType. 23

org/apache/hadoop/hbase/quotas/QuotaLimiterFactory.java

Severity Category Rule Message Line
 Error design FinalClass Class QuotaLimiterFactory should be declared as final. 18

org/apache/hadoop/hbase/quotas/QuotaObserverChore.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.quotas.QuotaSnapshotStore.ViolationState. 39
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot. 41
 Error sizes LineLength Line is longer than 100 characters (found 101). 250
 Error sizes LineLength Line is longer than 100 characters (found 102). 696

org/apache/hadoop/hbase/quotas/QuotaSettingsFactory.java

Severity Category Rule Message Line
 Error design FinalClass Class QuotaSettingsFactory should be declared as final. 26

org/apache/hadoop/hbase/quotas/QuotaSnapshotStore.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 118). 43

org/apache/hadoop/hbase/quotas/QuotaTableUtil.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.HBaseProtos. 48
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ipc.RpcControllerFactory. 57
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 79
 Error sizes LineLength Line is longer than 100 characters (found 120). 386

org/apache/hadoop/hbase/quotas/RateLimiter.java

Severity Category Rule Message Line
 Error whitespace ParenPad ')' is preceded with whitespace. 190

org/apache/hadoop/hbase/quotas/RegionServerSpaceQuotaManager.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 111). 199

org/apache/hadoop/hbase/quotas/SpaceQuotaSnapshot.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 138). 31
 Error design VisibilityModifier Variable 'policy' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'inViolation' must be private and have accessor methods. 45

org/apache/hadoop/hbase/quotas/SpaceQuotaSnapshotNotifierFactory.java

Severity Category Rule Message Line
 Error design FinalClass Class SpaceQuotaSnapshotNotifierFactory should be declared as final. 28

org/apache/hadoop/hbase/quotas/SpaceViolationPolicyEnforcement.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.quotas.SpaceViolationPolicy. 25
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.quotas.SpaceViolationPolicy. 25

org/apache/hadoop/hbase/quotas/SpaceViolationPolicyEnforcementFactory.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement. 21
 Error design FinalClass Class SpaceViolationPolicyEnforcementFactory should be declared as final. 33

org/apache/hadoop/hbase/quotas/TableQuotaSnapshotStore.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 112). 50

org/apache/hadoop/hbase/quotas/TimeBasedLimiter.java

Severity Category Rule Message Line
 Error design FinalClass Class TimeBasedLimiter should be declared as final. 33

org/apache/hadoop/hbase/quotas/policies/AbstractViolationPolicyEnforcement.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'rss' must be private and have accessor methods. 36
 Error design VisibilityModifier Variable 'tableName' must be private and have accessor methods. 37
 Error design VisibilityModifier Variable 'quotaSnapshot' must be private and have accessor methods. 38

org/apache/hadoop/hbase/quotas/policies/DefaultViolationPolicyEnforcement.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement. 30

org/apache/hadoop/hbase/quotas/policies/DisableTableViolationPolicyEnforcement.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement. 29
 Error blocks EmptyBlock Must have at least one statement. 49
 Error blocks EmptyBlock Must have at least one statement. 64

org/apache/hadoop/hbase/quotas/policies/MissingSnapshotViolationPolicyEnforcement.java

Severity Category Rule Message Line
 Error design FinalClass Class MissingSnapshotViolationPolicyEnforcement should be declared as final. 32

org/apache/hadoop/hbase/quotas/policies/NoInsertsViolationPolicyEnforcement.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement. 26

org/apache/hadoop/hbase/quotas/policies/NoWritesCompactionsViolationPolicyEnforcement.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement. 24

org/apache/hadoop/hbase/quotas/policies/NoWritesViolationPolicyEnforcement.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement. 27

org/apache/hadoop/hbase/regionserver/AbstractMultiFileWriter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'writerFactory' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'sourceScanner' must be private and have accessor methods. 44

org/apache/hadoop/hbase/regionserver/CompactionTool.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.regionserver.HRegion. 55
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.regionserver.HRegionFileSystem. 56
 Error sizes LineLength Line is longer than 100 characters (found 109). 110
 Error sizes LineLength Line is longer than 100 characters (found 118). 462
 Error sizes LineLength Line is longer than 100 characters (found 116). 465

org/apache/hadoop/hbase/regionserver/DefaultMemStore.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'cellSet' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'snapshot' must be private and have accessor methods. 85
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'size' must be private and have accessor methods. 90
 Error design VisibilityModifier Variable 'timeOfOldestEdit' must be private and have accessor methods. 94
 Error design VisibilityModifier Variable 'timeRangeTracker' must be private and have accessor methods. 96
 Error design VisibilityModifier Variable 'snapshotTimeRangeTracker' must be private and have accessor methods. 97
 Error design VisibilityModifier Variable 'allocator' must be private and have accessor methods. 99
 Error design VisibilityModifier Variable 'snapshotAllocator' must be private and have accessor methods. 100
 Error design VisibilityModifier Variable 'snapshotId' must be private and have accessor methods. 101
 Error design VisibilityModifier Variable 'tagsPresent' must be private and have accessor methods. 102
 Error sizes LineLength Line is longer than 100 characters (found 113). 174
 Error whitespace ParenPad '(' is followed by whitespace. 591
 Error whitespace ParenPad ')' is preceded with whitespace. 591
 Error design VisibilityModifier Variable 'cell' must be private and have accessor methods. 630
 Error design VisibilityModifier Variable 'set' must be private and have accessor methods. 631
 Error design VisibilityModifier Variable 'allocatorAtCreation' must be private and have accessor methods. 709
 Error design VisibilityModifier Variable 'snapshotAllocatorAtCreation' must be private and have accessor methods. 710
 Error blocks EmptyBlock Must have at least one statement. 1105

org/apache/hadoop/hbase/regionserver/FlushPolicy.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'region' must be private and have accessor methods. 34

org/apache/hadoop/hbase/regionserver/FlushPolicyFactory.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 36

org/apache/hadoop/hbase/regionserver/FlushRequestListener.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 106). 32

org/apache/hadoop/hbase/regionserver/HMobStore.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.CellComparator. 37
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.master.TableLockManager. 53
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.master.TableLockManager.TableLock. 54
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.compactions.CompactionContext. 61
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputController. 62
 Error sizes LineLength Line is longer than 100 characters (found 101). 243

org/apache/hadoop/hbase/regionserver/HRegion.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.io.UnsupportedEncodingException. 25
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseIOException. 81
 Error design VisibilityModifier Variable 'closed' must be private and have accessor methods. 225
 Error design VisibilityModifier Variable 'closing' must be private and have accessor methods. 231
 Error design VisibilityModifier Variable 'lastReplayedOpenRegionSeqId' must be private and have accessor methods. 264
 Error design VisibilityModifier Variable 'lastReplayedCompactionSeqId' must be private and have accessor methods. 265
 Error design VisibilityModifier Variable 'stores' must be private and have accessor methods. 279
 Error design VisibilityModifier Variable 'memstoreSize' must be private and have accessor methods. 285
 Error design VisibilityModifier Variable 'numMutationsWithoutWAL' must be private and have accessor methods. 288
 Error design VisibilityModifier Variable 'dataInMemoryWithoutWAL' must be private and have accessor methods. 289
 Error design VisibilityModifier Variable 'checkAndMutateChecksPassed' must be private and have accessor methods. 292
 Error design VisibilityModifier Variable 'checkAndMutateChecksFailed' must be private and have accessor methods. 293
 Error design VisibilityModifier Variable 'readRequestsCount' must be private and have accessor methods. 296
 Error design VisibilityModifier Variable 'writeRequestsCount' must be private and have accessor methods. 297
 Error design VisibilityModifier Variable 'compactionsFinished' must be private and have accessor methods. 303
 Error design VisibilityModifier Variable 'compactionNumFilesCompacted' must be private and have accessor methods. 304
 Error design VisibilityModifier Variable 'compactionNumBytesCompacted' must be private and have accessor methods. 305
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 309
 Error design VisibilityModifier Variable 'busyWaitDuration' must be private and have accessor methods. 321
 Error design VisibilityModifier Variable 'maxBusyWaitMultiplier' must be private and have accessor methods. 327
 Error design VisibilityModifier Variable 'maxBusyWaitDuration' must be private and have accessor methods. 331
 Error design VisibilityModifier Variable 'rowProcessorExecutor' must be private and have accessor methods. 335
 Error design VisibilityModifier Variable 'maxSeqIdInStores' must be private and have accessor methods. 359
 Error design VisibilityModifier Variable 'flushing' must be private and have accessor methods. 402
 Error design VisibilityModifier Variable 'flushRequested' must be private and have accessor methods. 404
 Error design VisibilityModifier Variable 'compacting' must be private and have accessor methods. 406
 Error design VisibilityModifier Variable 'writesEnabled' must be private and have accessor methods. 408
 Error design VisibilityModifier Variable 'readOnly' must be private and have accessor methods. 410
 Error design VisibilityModifier Variable 'readsEnabled' must be private and have accessor methods. 413
 Error design VisibilityModifier Variable 'result' must be private and have accessor methods. 448
 Error design VisibilityModifier Variable 'failureReason' must be private and have accessor methods. 449
 Error design VisibilityModifier Variable 'flushSequenceId' must be private and have accessor methods. 450
 Error design VisibilityModifier Variable 'wroteFlushWalMarker' must be private and have accessor methods. 451
 Error design VisibilityModifier Variable 'result' must be private and have accessor methods. 527
 Error design VisibilityModifier Variable 'storeFlushCtxs' must be private and have accessor methods. 528
 Error design VisibilityModifier Variable 'committedFiles' must be private and have accessor methods. 529
 Error design VisibilityModifier Variable 'storeFlushableSize' must be private and have accessor methods. 530
 Error design VisibilityModifier Variable 'startTime' must be private and have accessor methods. 531
 Error design VisibilityModifier Variable 'flushOpSeqId' must be private and have accessor methods. 532
 Error design VisibilityModifier Variable 'flushedSeqId' must be private and have accessor methods. 533
 Error design VisibilityModifier Variable 'totalFlushableSize' must be private and have accessor methods. 534
 Error design VisibilityModifier Variable 'writestate' must be private and have accessor methods. 623
 Error design VisibilityModifier Variable 'memstoreFlushSize' must be private and have accessor methods. 625
 Error design VisibilityModifier Variable 'timestampSlop' must be private and have accessor methods. 626
 Error design VisibilityModifier Variable 'rowProcessorTimeout' must be private and have accessor methods. 627
 Error design VisibilityModifier Variable 'rsServices' must be private and have accessor methods. 633
 Error design VisibilityModifier Variable 'threadWakeFrequency' must be private and have accessor methods. 639
 Error design VisibilityModifier Variable 'lock' must be private and have accessor methods. 641
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 685
 Error sizes MethodLength Method length is 152 lines (max allowed is 150). 1441
 Error sizes MethodLength Method length is 193 lines (max allowed is 150). 2262
 Error coding InnerAssignment Inner assignments should be avoided. 2381
 Error sizes LineLength Line is longer than 100 characters (found 110). 2455
 Error design VisibilityModifier Variable 'operations' must be private and have accessor methods. 2854
 Error design VisibilityModifier Variable 'nextIndexToProcess' must be private and have accessor methods. 2855
 Error design VisibilityModifier Variable 'retCodeDetails' must be private and have accessor methods. 2856
 Error design VisibilityModifier Variable 'walEditsFromCoprocessors' must be private and have accessor methods. 2857
 Error sizes MethodLength Method length is 436 lines (max allowed is 150). 3075
 Error sizes MethodLength Method length is 185 lines (max allowed is 150). 4206
 Error whitespace ParenPad ')' is preceded with whitespace. 4803
 Error sizes LineLength Line is longer than 100 characters (found 114). 5416
 Error sizes MethodLength Method length is 193 lines (max allowed is 150). 5421
 Error design VisibilityModifier Variable 'storeHeap' must be private and have accessor methods. 5638
 Error design VisibilityModifier Variable 'joinedHeap' must be private and have accessor methods. 5641
 Error design VisibilityModifier Variable 'joinedContinuationRow' must be private and have accessor methods. 5645
 Error design VisibilityModifier Variable 'stopRow' must be private and have accessor methods. 5646
 Error design VisibilityModifier Variable 'isScan' must be private and have accessor methods. 5649
 Error design VisibilityModifier Variable 'region' must be private and have accessor methods. 5653
 Error sizes LineLength Line is longer than 100 characters (found 111). 5786
 Error sizes MethodLength Method length is 201 lines (max allowed is 150). 5929
 Error coding InnerAssignment Inner assignments should be avoided. 6181
 Error sizes LineLength Line is longer than 100 characters (found 102). 6380
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 6751
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 6763
 Error sizes MethodLength Method length is 162 lines (max allowed is 150). 7014
 Error sizes LineLength Line is longer than 100 characters (found 101). 7141
 Error sizes LineLength Line is longer than 100 characters (found 104). 7209
 Error sizes MethodLength Method length is 230 lines (max allowed is 150). 7237
 Error coding MissingSwitchDefault switch without "default" clause. 8178

org/apache/hadoop/hbase/regionserver/HRegionFileSystem.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 101). 840
 Error sizes LineLength Line is longer than 100 characters (found 101). 1115

org/apache/hadoop/hbase/regionserver/HRegionServer.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.http.HttpServer. 103
 Error design VisibilityModifier Variable 'regionsInTransitionInRS' must be private and have accessor methods. 229
 Error design VisibilityModifier Variable 'cacheFlusher' must be private and have accessor methods. 233
 Error design VisibilityModifier Variable 'hMemManager' must be private and have accessor methods. 235
 Error design VisibilityModifier Variable 'initLatch' must be private and have accessor methods. 236
 Error design VisibilityModifier Variable 'clusterConnection' must be private and have accessor methods. 243
 Error design VisibilityModifier Variable 'metaTableLocator' must be private and have accessor methods. 251
 Error design VisibilityModifier Variable 'tableDescriptors' must be private and have accessor methods. 260
 Error design VisibilityModifier Variable 'replicationSourceHandler' must be private and have accessor methods. 263
 Error design VisibilityModifier Variable 'replicationSinkHandler' must be private and have accessor methods. 264
 Error design VisibilityModifier Variable 'compactSplitThread' must be private and have accessor methods. 267
 Error design VisibilityModifier Variable 'onlineRegions' must be private and have accessor methods. 273
 Error design VisibilityModifier Variable 'regionFavoredNodesMap' must be private and have accessor methods. 284
 Error design VisibilityModifier Variable 'recoveringRegions' must be private and have accessor methods. 291
 Error design VisibilityModifier Variable 'leases' must be private and have accessor methods. 295
 Error design VisibilityModifier Variable 'service' must be private and have accessor methods. 298
 Error design VisibilityModifier Variable 'fsOk' must be private and have accessor methods. 301
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 302
 Error design VisibilityModifier Variable 'walFs' must be private and have accessor methods. 303
 Error design VisibilityModifier Variable 'rowlocks' must be private and have accessor methods. 314
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 322
 Error design VisibilityModifier Variable 'lock' must be private and have accessor methods. 327
 Error design VisibilityModifier Variable 'numRetries' must be private and have accessor methods. 329
 Error design VisibilityModifier Variable 'threadWakeFrequency' must be private and have accessor methods. 330
 Error design VisibilityModifier Variable 'msgInterval' must be private and have accessor methods. 331
 Error design VisibilityModifier Variable 'numRegionsToReport' must be private and have accessor methods. 333
 Error design VisibilityModifier Variable 'rpcClient' must be private and have accessor methods. 338
 Error design VisibilityModifier Variable 'infoServer' must be private and have accessor methods. 348
 Error design VisibilityModifier Variable 'metricsRegionServer' must be private and have accessor methods. 354
 Error design VisibilityModifier Variable 'metricsTable' must be private and have accessor methods. 355
 Error design VisibilityModifier Variable 'compactionChecker' must be private and have accessor methods. 366
 Error design VisibilityModifier Variable 'periodicFlusher' must be private and have accessor methods. 371
 Error design VisibilityModifier Variable 'walFactory' must be private and have accessor methods. 373
 Error design VisibilityModifier Variable 'walRoller' must be private and have accessor methods. 377
 Error design VisibilityModifier Variable 'metawalRoller' must be private and have accessor methods. 379
 Error design VisibilityModifier Variable 'online' must be private and have accessor methods. 382
 Error design VisibilityModifier Variable 'zooKeeper' must be private and have accessor methods. 385
 Error design VisibilityModifier Variable 'clusterStatusTracker' must be private and have accessor methods. 391
 Error design VisibilityModifier Variable 'sleeper' must be private and have accessor methods. 397
 Error design VisibilityModifier Variable 'cacheConfig' must be private and have accessor methods. 405
 Error design VisibilityModifier Variable 'mobCacheConfig' must be private and have accessor methods. 407
 Error design VisibilityModifier Variable 'serverName' must be private and have accessor methods. 422
 Error design VisibilityModifier Variable 'startcode' must be private and have accessor methods. 444
 Error design VisibilityModifier Variable 'tableLockManager' must be private and have accessor methods. 472
 Error design VisibilityModifier Variable 'nonceManager' must be private and have accessor methods. 492
 Error design VisibilityModifier Variable 'rpcServices' must be private and have accessor methods. 496
 Error design VisibilityModifier Variable 'csm' must be private and have accessor methods. 498
 Error design VisibilityModifier Variable 'configurationManager' must be private and have accessor methods. 506
 Error design VisibilityModifier Variable 'fsUtilizationChore' must be private and have accessor methods. 508
 Error sizes MethodLength Method length is 227 lines (max allowed is 150). 935
 Error blocks EmptyBlock Must have at least one statement. 1077
 Error blocks EmptyBlock Must have at least one statement. 1147
 Error design VisibilityModifier Variable 'server' must be private and have accessor methods. 1712
 Error blocks EmptyBlock Must have at least one statement. 2260
 Error design VisibilityModifier Variable 'movedRegions' must be private and have accessor methods. 3242
 Error design VisibilityModifier Variable 'stoppable' must be private and have accessor methods. 3307

org/apache/hadoop/hbase/regionserver/HRegionServerCommandLine.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 78

org/apache/hadoop/hbase/regionserver/HStore.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'memstore' must be private and have accessor methods. 140
 Error design VisibilityModifier Variable 'region' must be private and have accessor methods. 142
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 145
 Error design VisibilityModifier Variable 'cacheConf' must be private and have accessor methods. 146
 Error design VisibilityModifier Variable 'forceMajor' must be private and have accessor methods. 148
 Error design VisibilityModifier Variable 'closeCheckInterval' must be private and have accessor methods. 150
 Error design VisibilityModifier Variable 'lock' must be private and have accessor methods. 163
 Error design VisibilityModifier Variable 'filesCompacting' must be private and have accessor methods. 169
 Error design VisibilityModifier Variable 'blocksize' must be private and have accessor methods. 175
 Error design VisibilityModifier Variable 'checksumType' must be private and have accessor methods. 179
 Error design VisibilityModifier Variable 'bytesPerChecksum' must be private and have accessor methods. 180
 Error design VisibilityModifier Variable 'storeEngine' must be private and have accessor methods. 185
 Error design VisibilityModifier Variable 'cryptoContext' must be private and have accessor methods. 197
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 496
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 508
 Error coding EmptyStatement Empty statement. 1236
 Error design FinalClass Class StoreFlusherImpl should be declared as final. 2383
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 2644

org/apache/hadoop/hbase/regionserver/HeapMemStoreLAB.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'chunkSize' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'maxAlloc' must be private and have accessor methods. 68

org/apache/hadoop/hbase/regionserver/KeyPrefixRegionSplitPolicy.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 37

org/apache/hadoop/hbase/regionserver/KeyValueHeap.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'heap' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'current' must be private and have accessor methods. 59
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'kvComparator' must be private and have accessor methods. 172

org/apache/hadoop/hbase/regionserver/Leases.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'leaseCheckFrequency' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'stopRequested' must be private and have accessor methods. 62
 Error whitespace ParenPad ')' is preceded with whitespace. 84
 Error whitespace ParenPad '(' is followed by whitespace. 110
 Error whitespace ParenPad ')' is preceded with whitespace. 193

org/apache/hadoop/hbase/regionserver/LogRoller.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 21 - java.io.IOException. 39
 Error imports RedundantImport Duplicate import to line 24 - java.util.concurrent.atomic.AtomicBoolean. 40
 Error imports RedundantImport Duplicate import to line 25 - java.util.concurrent.locks.ReentrantLock. 41
 Error design VisibilityModifier Variable 'services' must be private and have accessor methods. 63
 Error blocks EmptyBlock Must have at least one statement. 128

org/apache/hadoop/hbase/regionserver/LruHashMap.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'key' must be private and have accessor methods. 930
 Error design VisibilityModifier Variable 'value' must be private and have accessor methods. 932
 Error design VisibilityModifier Variable 'hash' must be private and have accessor methods. 934
 Error design VisibilityModifier Variable 'next' must be private and have accessor methods. 936
 Error design VisibilityModifier Variable 'prevPtr' must be private and have accessor methods. 939
 Error design VisibilityModifier Variable 'nextPtr' must be private and have accessor methods. 941
 Error design VisibilityModifier Variable 'heapSize' must be private and have accessor methods. 944

org/apache/hadoop/hbase/regionserver/MemStoreChunkPool.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'chunkPoolDisabled' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'mcp' must be private and have accessor methods. 152

org/apache/hadoop/hbase/regionserver/MemStoreFlusher.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'globalMemStoreLimit' must be private and have accessor methods. 92
 Error design VisibilityModifier Variable 'globalMemStoreLimitLowMarkPercent' must be private and have accessor methods. 93
 Error design VisibilityModifier Variable 'globalMemStoreLimitLowMark' must be private and have accessor methods. 94
 Error design FinalClass Class FlushHandler should be declared as final. 227
 Error coding EqualsHashCode Definition of 'equals()' without corresponding definition of 'hashCode()'. 690

org/apache/hadoop/hbase/regionserver/MetricsRegionServerSourceImpl.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'rsWrap' must be private and have accessor methods. 38
 Error sizes MethodLength Method length is 181 lines (max allowed is 150). 322
 Error sizes LineLength Line is longer than 100 characters (found 111). 346
 Error sizes LineLength Line is longer than 100 characters (found 104). 465
 Error sizes LineLength Line is longer than 100 characters (found 102). 469

org/apache/hadoop/hbase/regionserver/MetricsRegionServerWrapperImpl.java

Severity Category Rule Message Line
 Error sizes MethodLength Method length is 194 lines (max allowed is 150). 598

org/apache/hadoop/hbase/regionserver/MetricsTable.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 102). 30

org/apache/hadoop/hbase/regionserver/MetricsTableAggregateSourceImpl.java

Severity Category Rule Message Line
 Error whitespace ParenPad '(' is followed by whitespace. 68

org/apache/hadoop/hbase/regionserver/MetricsTableLatenciesImpl.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'getTimeHisto' must be private and have accessor methods. 40
 Error design VisibilityModifier Variable 'incrementTimeHisto' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'appendTimeHisto' must be private and have accessor methods. 42
 Error design VisibilityModifier Variable 'putTimeHisto' must be private and have accessor methods. 43
 Error design VisibilityModifier Variable 'deleteTimeHisto' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'scanTimeHisto' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'scanSizeHisto' must be private and have accessor methods. 46

org/apache/hadoop/hbase/regionserver/MetricsTableSourceImpl.java

Severity Category Rule Message Line
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource.*. 21

org/apache/hadoop/hbase/regionserver/MetricsTableWrapperAggregateImpl.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'readRequestCount' must be private and have accessor methods. 257
 Error design VisibilityModifier Variable 'writeRequestCount' must be private and have accessor methods. 258
 Error design VisibilityModifier Variable 'memstoreSize' must be private and have accessor methods. 259
 Error design VisibilityModifier Variable 'regionCount' must be private and have accessor methods. 260
 Error design VisibilityModifier Variable 'storeCount' must be private and have accessor methods. 261
 Error design VisibilityModifier Variable 'storeFileCount' must be private and have accessor methods. 262
 Error design VisibilityModifier Variable 'storeFileSize' must be private and have accessor methods. 263
 Error design VisibilityModifier Variable 'maxStoreFileAge' must be private and have accessor methods. 264
 Error design VisibilityModifier Variable 'minStoreFileAge' must be private and have accessor methods. 265
 Error design VisibilityModifier Variable 'totalStoreFileAge' must be private and have accessor methods. 266
 Error design VisibilityModifier Variable 'referenceFileCount' must be private and have accessor methods. 267

org/apache/hadoop/hbase/regionserver/MetricsUserAggregate.java

Severity Category Rule Message Line
 Error blocks EmptyBlock Must have at least one statement. 55

org/apache/hadoop/hbase/regionserver/MetricsUserAggregateSourceImpl.java

Severity Category Rule Message Line
 Error whitespace ParenPad '(' is followed by whitespace. 94

org/apache/hadoop/hbase/regionserver/MultiRowMutationProcessor.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'rowsToLock' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'mutations' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'miniBatch' must be private and have accessor methods. 46

org/apache/hadoop/hbase/regionserver/RSRpcServices.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.QuotaProtos.SpaceViolationPolicy. 159
 Error imports RedundantImport Duplicate import to line 165 - org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement. 169
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.HRegion.RegionScannerImpl. 173
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.Leases.Lease. 174
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.User. 183
 Error design VisibilityModifier Variable 'requestCount' must be private and have accessor methods. 230
 Error design VisibilityModifier Variable 'rpcGetRequestCount' must be private and have accessor methods. 233
 Error design VisibilityModifier Variable 'rpcScanRequestCount' must be private and have accessor methods. 236
 Error design VisibilityModifier Variable 'rpcMultiRequestCount' must be private and have accessor methods. 239
 Error design VisibilityModifier Variable 'rpcMutateRequestCount' must be private and have accessor methods. 242
 Error design VisibilityModifier Variable 'rpcServer' must be private and have accessor methods. 245
 Error design VisibilityModifier Variable 'isa' must be private and have accessor methods. 246
 Error sizes LineLength Line is longer than 100 characters (found 101). 523
 Error sizes LineLength Line is longer than 100 characters (found 101). 629
 Error misc ArrayTypeStyle Array brackets at illegal position. 765
 Error sizes MethodLength Method length is 176 lines (max allowed is 150). 1459
 Error sizes LineLength Line is longer than 100 characters (found 103). 1534
 Error sizes LineLength Line is longer than 100 characters (found 109). 1735
 Error sizes MethodLength Method length is 393 lines (max allowed is 150). 2333
 Error blocks EmptyBlock Must have at least one statement. 2360
 Error sizes LineLength Line is longer than 100 characters (found 113). 2642
 Error sizes LineLength Line is longer than 100 characters (found 107). 2675

org/apache/hadoop/hbase/regionserver/RegionCoprocessorHost.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'sharedData' must be private and have accessor methods. 109
 Error design VisibilityModifier Variable 'rsServices' must be private and have accessor methods. 195
 Error design VisibilityModifier Variable 'region' must be private and have accessor methods. 197
 Error blocks EmptyBlock Must have at least one statement. 251
 Error whitespace ParenPad '(' is followed by whitespace. 360
 Error whitespace ParenPad ')' is preceded with whitespace. 360
 Error sizes LineLength Line is longer than 100 characters (found 131). 489

org/apache/hadoop/hbase/regionserver/RegionMergeTransactionImpl.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 305

org/apache/hadoop/hbase/regionserver/RegionSplitPolicy.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'region' must be private and have accessor methods. 47

org/apache/hadoop/hbase/regionserver/ReversedMobStoreScanner.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'mobStore' must be private and have accessor methods. 41

org/apache/hadoop/hbase/regionserver/ReversedRegionScannerImpl.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 69

org/apache/hadoop/hbase/regionserver/RpcSchedulerFactory.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 40

org/apache/hadoop/hbase/regionserver/ScanDeleteTracker.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'hasFamilyStamp' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'familyStamp' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'familyVersionStamps' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'deleteBuffer' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'deleteOffset' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'deleteLength' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'deleteType' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'deleteTimestamp' must be private and have accessor methods. 55

org/apache/hadoop/hbase/regionserver/ScanQueryMatcher.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'row' must be private and have accessor methods. 93
 Error design VisibilityModifier Variable 'rowOffset' must be private and have accessor methods. 94
 Error design VisibilityModifier Variable 'rowLength' must be private and have accessor methods. 95
 Error design VisibilityModifier Variable 'maxReadPointToTrackVersions' must be private and have accessor methods. 111
 Error sizes MethodLength Method length is 191 lines (max allowed is 150). 277
 Error sizes LineLength Line is longer than 100 characters (found 108). 568

org/apache/hadoop/hbase/regionserver/ScannerContext.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.util.List. 20
 Error design VisibilityModifier Variable 'limits' must be private and have accessor methods. 58
 Error design VisibilityModifier Variable 'progress' must be private and have accessor methods. 59
 Error design VisibilityModifier Variable 'scannerState' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'keepProgress' must be private and have accessor methods. 96
 Error design VisibilityModifier Variable 'keepProgress' must be private and have accessor methods. 333
 Error design VisibilityModifier Variable 'limits' must be private and have accessor methods. 334
 Error design VisibilityModifier Variable 'depth' must be private and have accessor methods. 449
 Error design VisibilityModifier Variable 'batch' must be private and have accessor methods. 490
 Error design VisibilityModifier Variable 'sizeScope' must be private and have accessor methods. 492
 Error design VisibilityModifier Variable 'size' must be private and have accessor methods. 493
 Error design VisibilityModifier Variable 'timeScope' must be private and have accessor methods. 495
 Error design VisibilityModifier Variable 'time' must be private and have accessor methods. 496

org/apache/hadoop/hbase/regionserver/ServerNonceManager.java

Severity Category Rule Message Line
 Error misc UpperEll Should use uppercase 'L'. 98

org/apache/hadoop/hbase/regionserver/ShutdownHook.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 40
 Error blocks EmptyBlock Must have at least one statement. 182

org/apache/hadoop/hbase/regionserver/SimpleRpcSchedulerFactory.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 35
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 38

org/apache/hadoop/hbase/regionserver/SplitLogWorker.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'worker' must be private and have accessor methods. 68

org/apache/hadoop/hbase/regionserver/SplitTransactionImpl.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'std' must be private and have accessor methods. 75
 Error design VisibilityModifier Variable 'useZKForAssignment' must be private and have accessor methods. 76
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 227
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 588
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 588
 Error whitespace MethodParamPad '(' is preceded with whitespace. 799

org/apache/hadoop/hbase/regionserver/StoreEngine.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'storeFlusher' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'compactionPolicy' must be private and have accessor methods. 42
 Error design VisibilityModifier Variable 'compactor' must be private and have accessor methods. 43
 Error design VisibilityModifier Variable 'storeFileManager' must be private and have accessor methods. 44

org/apache/hadoop/hbase/regionserver/StoreFile.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - com.google.common.annotations.VisibleForTesting. 21
 Error imports RedundantImport Duplicate import to line 22 - com.google.common.base.Function. 69
 Error imports RedundantImport Duplicate import to line 23 - com.google.common.base.Preconditions. 70
 Error imports RedundantImport Duplicate import to line 24 - com.google.common.collect.ImmutableList. 71
 Error imports RedundantImport Duplicate import to line 25 - com.google.common.collect.Ordering. 72
 Error blocks EmptyBlock Must have at least one statement. 523
 Error design FinalClass Class Writer should be declared as final. 773
 Error design VisibilityModifier Variable 'bytesPerChecksum' must be private and have accessor methods. 786
 Error design VisibilityModifier Variable 'timeRangeTracker' must be private and have accessor methods. 788
 Error design VisibilityModifier Variable 'isTimeRangeTrackerSet' must be private and have accessor methods. 795
 Error design VisibilityModifier Variable 'writer' must be private and have accessor methods. 797
 Error design VisibilityModifier Variable 'generalBloomFilter' must be private and have accessor methods. 1109
 Error design VisibilityModifier Variable 'deleteFamilyBloomFilter' must be private and have accessor methods. 1110
 Error design VisibilityModifier Variable 'bloomFilterType' must be private and have accessor methods. 1111
 Error design VisibilityModifier Variable 'timeRangeTracker' must be private and have accessor methods. 1113
 Error design VisibilityModifier Variable 'sequenceID' must be private and have accessor methods. 1114
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1191
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1209

org/apache/hadoop/hbase/regionserver/StoreFlusher.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'store' must be private and have accessor methods. 42

org/apache/hadoop/hbase/regionserver/StoreScanner.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'store' must be private and have accessor methods. 60
 Error design VisibilityModifier Variable 'matcher' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'heap' must be private and have accessor methods. 62
 Error design VisibilityModifier Variable 'cacheBlocks' must be private and have accessor methods. 63
 Error design VisibilityModifier Variable 'countPerRow' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'storeLimit' must be private and have accessor methods. 66
 Error design VisibilityModifier Variable 'storeOffset' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'closing' must be private and have accessor methods. 71
 Error design VisibilityModifier Variable 'isGet' must be private and have accessor methods. 72
 Error design VisibilityModifier Variable 'explicitColumnQuery' must be private and have accessor methods. 73
 Error design VisibilityModifier Variable 'useRowColBloom' must be private and have accessor methods. 74
 Error design VisibilityModifier Variable 'isParallelSeekEnabled' must be private and have accessor methods. 78
 Error design VisibilityModifier Variable 'executor' must be private and have accessor methods. 79
 Error design VisibilityModifier Variable 'scan' must be private and have accessor methods. 80
 Error design VisibilityModifier Variable 'columns' must be private and have accessor methods. 81
 Error design VisibilityModifier Variable 'oldestUnexpiredTS' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'now' must be private and have accessor methods. 83
 Error design VisibilityModifier Variable 'minVersions' must be private and have accessor methods. 84
 Error design VisibilityModifier Variable 'maxRowSize' must be private and have accessor methods. 85
 Error design VisibilityModifier Variable 'cellsPerHeartbeatCheck' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'lazySeekEnabledGlobally' must be private and have accessor methods. 101
 Error design VisibilityModifier Variable 'lastTop' must be private and have accessor methods. 118
 Error design VisibilityModifier Variable 'lock' must be private and have accessor methods. 122
 Error design VisibilityModifier Variable 'readPt' must be private and have accessor methods. 124
 Error sizes MethodLength Method length is 177 lines (max allowed is 150). 480

org/apache/hadoop/hbase/regionserver/StoreUtils.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 29

org/apache/hadoop/hbase/regionserver/StorefileRefresherChore.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 118). 111

org/apache/hadoop/hbase/regionserver/StripeMultiFileWriter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 43
 Error design VisibilityModifier Variable 'existingWriters' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'boundaries' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'lastRowInCurrentWriter' must be private and have accessor methods. 275

org/apache/hadoop/hbase/regionserver/StripeStoreFileManager.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'stripeEndRows' must be private and have accessor methods. 94
 Error design VisibilityModifier Variable 'stripeFiles' must be private and have accessor methods. 101
 Error design VisibilityModifier Variable 'level0Files' must be private and have accessor methods. 104
 Error design VisibilityModifier Variable 'allFilesCached' must be private and have accessor methods. 107

org/apache/hadoop/hbase/regionserver/StripeStoreFlusher.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter. 35
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 124

org/apache/hadoop/hbase/regionserver/TimeRangeTracker.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'minimumTimestamp' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'maximumTimestamp' must be private and have accessor methods. 42

org/apache/hadoop/hbase/regionserver/compactions/AbstractMultiOutputCompactor.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.ScanType. 31
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.StoreFile. 33
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.StoreFileScanner. 35
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputController. 37
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.compactions.CompactionThroughputController. 37
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.User. 38
 Error imports UnusedImports Unused import - com.google.common.io.Closeables. 40

org/apache/hadoop/hbase/regionserver/compactions/CompactionConfiguration.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'storeConfigInfo' must be private and have accessor methods. 83

org/apache/hadoop/hbase/regionserver/compactions/CompactionContext.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'request' must be private and have accessor methods. 38

org/apache/hadoop/hbase/regionserver/compactions/CompactionPolicy.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'comConf' must be private and have accessor methods. 36
 Error design VisibilityModifier Variable 'storeConfigInfo' must be private and have accessor methods. 37

org/apache/hadoop/hbase/regionserver/compactions/CompactionProgress.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'totalCompactingKVs' must be private and have accessor methods. 37
 Error design VisibilityModifier Variable 'currentCompactedKVs' must be private and have accessor methods. 39
 Error design VisibilityModifier Variable 'totalCompactedSize' must be private and have accessor methods. 41
 Error coding InnerAssignment Inner assignments should be avoided. 61

org/apache/hadoop/hbase/regionserver/compactions/CompactionRequest.java

Severity Category Rule Message Line
 Error coding EqualsHashCode Definition of 'equals()' without corresponding definition of 'hashCode()'. 144

org/apache/hadoop/hbase/regionserver/compactions/CompactionThroughputControllerFactory.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 28

org/apache/hadoop/hbase/regionserver/compactions/Compactor.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.util.StringUtils. 59
 Error design VisibilityModifier Variable 'progress' must be private and have accessor methods. 71
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 73
 Error design VisibilityModifier Variable 'store' must be private and have accessor methods. 74
 Error design VisibilityModifier Variable 'compactionKVMax' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'compactionCompression' must be private and have accessor methods. 77
 Error design VisibilityModifier Variable 'keepSeqIdPeriod' must be private and have accessor methods. 80
 Error design VisibilityModifier Variable 'maxKeyCount' must be private and have accessor methods. 110
 Error design VisibilityModifier Variable 'earliestPutTs' must be private and have accessor methods. 112
 Error design VisibilityModifier Variable 'latestPutTs' must be private and have accessor methods. 114
 Error design VisibilityModifier Variable 'maxSeqId' must be private and have accessor methods. 116
 Error design VisibilityModifier Variable 'maxMVCCReadpoint' must be private and have accessor methods. 118
 Error design VisibilityModifier Variable 'maxTagsLength' must be private and have accessor methods. 120
 Error design VisibilityModifier Variable 'minSeqIdToKeep' must be private and have accessor methods. 122
 Error coding InnerAssignment Inner assignments should be avoided. 183
 Error design VisibilityModifier Variable 'defaultScannerFactory' must be private and have accessor methods. 233

org/apache/hadoop/hbase/regionserver/compactions/CurrentHourProvider.java

Severity Category Rule Message Line
 Error design FinalClass Class CurrentHourProvider should be declared as final. 25
 Error design VisibilityModifier Variable 'currentHour' must be private and have accessor methods. 30
 Error design VisibilityModifier Variable 'expirationTimeInMillis' must be private and have accessor methods. 31
 Error coding InnerAssignment Inner assignments should be avoided. 61

org/apache/hadoop/hbase/regionserver/compactions/DateTieredCompactor.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.ScanType. 30
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.StoreFileScanner. 33

org/apache/hadoop/hbase/regionserver/compactions/DefaultCompactor.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.io.InterruptedIOException. 23
 Error imports UnusedImports Unused import - java.util.ArrayList. 24
 Error imports UnusedImports Unused import - java.util.Collections. 26
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.ScanType. 35
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.StoreFileScanner. 39
 Error sizes LineLength Line is longer than 100 characters (found 105). 79

org/apache/hadoop/hbase/regionserver/compactions/OffPeakHours.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'startHour' must be private and have accessor methods. 80
 Error design VisibilityModifier Variable 'endHour' must be private and have accessor methods. 81

org/apache/hadoop/hbase/regionserver/compactions/PressureAwareCompactionThroughputController.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'maxThroughput' must be private and have accessor methods. 116

org/apache/hadoop/hbase/regionserver/compactions/StripeCompactionPolicy.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'request' must be private and have accessor methods. 395
 Error design VisibilityModifier Variable 'majorRangeFromRow' must be private and have accessor methods. 396
 Error design VisibilityModifier Variable 'majorRangeToRow' must be private and have accessor methods. 396
 Error coding InnerAssignment Inner assignments should be avoided. 433

org/apache/hadoop/hbase/regionserver/compactions/StripeCompactor.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.io.InterruptedIOException. 21
 Error imports UnusedImports Unused import - java.util.ArrayList. 22
 Error imports UnusedImports Unused import - java.util.Collection. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.compress.Compression. 31
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.StoreFile. 35
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.StoreScanner. 37
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.StoreFile.Writer. 39

org/apache/hadoop/hbase/regionserver/handler/FinishRegionRecoveringHandler.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'rss' must be private and have accessor methods. 34
 Error design VisibilityModifier Variable 'regionName' must be private and have accessor methods. 35
 Error design VisibilityModifier Variable 'path' must be private and have accessor methods. 36

org/apache/hadoop/hbase/regionserver/handler/OpenPriorityRegionHandler.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.regionserver.handler.OpenRegionHandler. 27

org/apache/hadoop/hbase/regionserver/handler/OpenRegionHandler.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'rsServices' must be private and have accessor methods. 49
 Error blocks EmptyBlock Must have at least one statement. 271

org/apache/hadoop/hbase/regionserver/handler/WALSplitterHandler.java

Severity Category Rule Message Line
 Error coding MissingSwitchDefault switch without "default" clause. 73

org/apache/hadoop/hbase/regionserver/snapshot/FlushSnapshotSubprocedure.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.Region.Operation. 37
 Error design VisibilityModifier Variable 'region' must be private and have accessor methods. 79

org/apache/hadoop/hbase/regionserver/snapshot/RegionServerSnapshotManager.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.zookeeper.KeeperException. 58
 Error sizes LineLength Line is longer than 100 characters (found 101). 81
 Error sizes LineLength Line is longer than 100 characters (found 102). 95
 Error blocks EmptyBlock Must have at least one statement. 371

org/apache/hadoop/hbase/regionserver/wal/CompressionContext.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'regionDict' must be private and have accessor methods. 38
 Error design VisibilityModifier Variable 'tableDict' must be private and have accessor methods. 39
 Error design VisibilityModifier Variable 'familyDict' must be private and have accessor methods. 40
 Error design VisibilityModifier Variable 'qualifierDict' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'rowDict' must be private and have accessor methods. 42
 Error design VisibilityModifier Variable 'tagCompressionContext' must be private and have accessor methods. 44

org/apache/hadoop/hbase/regionserver/wal/Compressor.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 44
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 105
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 142
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 181

org/apache/hadoop/hbase/regionserver/wal/FSHLog.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.KeyValue. 70
 Error imports RedundantImport Duplicate import to line 95 - com.google.common.annotations.VisibleForTesting. 107
 Error imports RedundantImport Duplicate import to line 97 - com.lmax.disruptor.BlockingWaitStrategy. 108
 Error imports RedundantImport Duplicate import to line 98 - com.lmax.disruptor.EventHandler. 109
 Error imports RedundantImport Duplicate import to line 99 - com.lmax.disruptor.ExceptionHandler. 110
 Error imports RedundantImport Duplicate import to line 100 - com.lmax.disruptor.LifecycleAware. 111
 Error imports RedundantImport Duplicate import to line 101 - com.lmax.disruptor.TimeoutException. 112
 Error imports RedundantImport Duplicate import to line 102 - com.lmax.disruptor.dsl.Disruptor. 113
 Error imports RedundantImport Duplicate import to line 103 - com.lmax.disruptor.dsl.ProducerType. 114
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 232
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 268
 Error design VisibilityModifier Variable 'writer' must be private and have accessor methods. 321
 Error design VisibilityModifier Variable 'LOG_NAME_COMPARATOR' must be private and have accessor methods. 415
 Error whitespace ParenPad '(' is followed by whitespace. 574
 Error whitespace ParenPad ')' is preceded with whitespace. 1206
 Error coding InnerAssignment Inner assignments should be avoided. 1379
 Error sizes LineLength Line is longer than 100 characters (found 112). 2119
 Error sizes LineLength Line is longer than 100 characters (found 102). 2120

org/apache/hadoop/hbase/regionserver/wal/HLogPrettyPrinter.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.io.FileNotFoundException. 20
 Error imports UnusedImports Unused import - java.util.ArrayList. 23
 Error imports UnusedImports Unused import - java.util.Date. 24
 Error imports UnusedImports Unused import - java.util.HashMap. 25
 Error imports UnusedImports Unused import - java.util.List. 26
 Error imports UnusedImports Unused import - java.util.Map. 27
 Error imports UnusedImports Unused import - org.apache.commons.cli.CommandLine. 29
 Error imports UnusedImports Unused import - org.apache.commons.cli.CommandLineParser. 30
 Error imports UnusedImports Unused import - org.apache.commons.cli.HelpFormatter. 31
 Error imports UnusedImports Unused import - org.apache.commons.cli.Options. 32
 Error imports UnusedImports Unused import - org.apache.commons.cli.ParseException. 33
 Error imports UnusedImports Unused import - org.apache.commons.cli.PosixParser. 34
 Error imports UnusedImports Unused import - org.apache.hadoop.conf.Configuration. 37
 Error imports UnusedImports Unused import - org.apache.hadoop.fs.FileSystem. 38
 Error imports UnusedImports Unused import - org.apache.hadoop.fs.Path. 39
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseConfiguration. 40
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.KeyValue. 41
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.Bytes. 42
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.FSUtils. 43
 Error imports UnusedImports Unused import - org.codehaus.jackson.map.ObjectMapper. 46
 Error misc UpperEll Should use uppercase 'L'. 71

org/apache/hadoop/hbase/regionserver/wal/KeyValueCompression.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 39
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 39

org/apache/hadoop/hbase/regionserver/wal/MetricsWALSourceImpl.java

Severity Category Rule Message Line
 Error misc UpperEll Should use uppercase 'L'. 58
 Error misc UpperEll Should use uppercase 'L'. 60
 Error misc UpperEll Should use uppercase 'L'. 66

org/apache/hadoop/hbase/regionserver/wal/ProtobufLogReader.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'inputStream' must be private and have accessor methods. 78
 Error design VisibilityModifier Variable 'cellDecoder' must be private and have accessor methods. 79
 Error design VisibilityModifier Variable 'byteStringUncompressor' must be private and have accessor methods. 80
 Error design VisibilityModifier Variable 'hasCompression' must be private and have accessor methods. 81
 Error design VisibilityModifier Variable 'hasTagCompression' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'trailer' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'trailerWarnSize' must be private and have accessor methods. 90
 Error sizes LineLength Line is longer than 100 characters (found 112). 103
 Error sizes LineLength Line is longer than 100 characters (found 153). 106
 Error design VisibilityModifier Variable 'result' must be private and have accessor methods. 122
 Error design VisibilityModifier Variable 'cellCodecClsName' must be private and have accessor methods. 123
 Error sizes LineLength Line is longer than 100 characters (found 194). 234
 Error sizes LineLength Line is longer than 100 characters (found 124). 369
 Error sizes LineLength Line is longer than 100 characters (found 181). 405
 Error sizes LineLength Line is longer than 100 characters (found 156). 412

org/apache/hadoop/hbase/regionserver/wal/ProtobufLogWriter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'output' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'cellEncoder' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'compressor' must be private and have accessor methods. 50
 Error coding InnerAssignment Inner assignments should be avoided. 152

org/apache/hadoop/hbase/regionserver/wal/ReaderBase.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 42
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 43
 Error design VisibilityModifier Variable 'path' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'edit' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'fileLength' must be private and have accessor methods. 46
 Error design VisibilityModifier Variable 'compressionContext' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'emptyCompressionContext' must be private and have accessor methods. 51

org/apache/hadoop/hbase/regionserver/wal/SequenceFileLogReader.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 129). 41
 Error design VisibilityModifier Variable 'reader' must be private and have accessor methods. 148
 Error design VisibilityModifier Variable 'entryStart' must be private and have accessor methods. 149
 Error blocks EmptyBlock Must have at least one statement. 283
 Error blocks EmptyBlock Must have at least one statement. 285
 Error blocks EmptyBlock Must have at least one statement. 303
 Error blocks EmptyBlock Must have at least one statement. 305

org/apache/hadoop/hbase/regionserver/wal/WALActionsListener.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 112). 138

org/apache/hadoop/hbase/regionserver/wal/WALCellCodec.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 129). 51
 Error design VisibilityModifier Variable 'compression' must be private and have accessor methods. 56
 Error design VisibilityModifier Variable 'statelessUncompressor' must be private and have accessor methods. 57

org/apache/hadoop/hbase/regionserver/wal/WALCoprocessorHost.java

Severity Category Rule Message Line
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - org.apache.hadoop.hbase.coprocessor.*. 27
 Error design VisibilityModifier Variable 'useLegacyPre' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'useLegacyPost' must be private and have accessor methods. 51

org/apache/hadoop/hbase/regionserver/wal/WALEdit.java

Severity Category Rule Message Line
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 107

org/apache/hadoop/hbase/regionserver/wal/WALUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 47

org/apache/hadoop/hbase/regionserver/wal/WriterBase.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'compressionContext' must be private and have accessor methods. 40
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 41
 Error sizes LineLength Line is longer than 100 characters (found 107). 44

org/apache/hadoop/hbase/replication/BaseReplicationEndpoint.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'ctx' must be private and have accessor methods. 38

org/apache/hadoop/hbase/replication/ReplicationEndpoint.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'entries' must be private and have accessor methods. 138
 Error design VisibilityModifier Variable 'size' must be private and have accessor methods. 139

org/apache/hadoop/hbase/replication/ReplicationFactory.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 30

org/apache/hadoop/hbase/replication/ReplicationStateZKBase.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'peerStateNodeName' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'replicationZNode' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'peersZNode' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'queuesZNode' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'hfileRefsZNode' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'ourClusterKey' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'zookeeper' must be private and have accessor methods. 56
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 57
 Error design VisibilityModifier Variable 'abortable' must be private and have accessor methods. 58
 Error design VisibilityModifier Variable 'replicationForBulkLoadEnabled' must be private and have accessor methods. 59

org/apache/hadoop/hbase/replication/regionserver/MetricsReplicationGlobalSourceSource.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 116). 69
 Error sizes LineLength Line is longer than 100 characters (found 116). 71
 Error sizes LineLength Line is longer than 100 characters (found 103). 75

org/apache/hadoop/hbase/replication/regionserver/MetricsReplicationSource.java

Severity Category Rule Message Line
 Error design InterfaceIsType interfaces should describe a type and hence have methods. 27

org/apache/hadoop/hbase/replication/regionserver/MetricsReplicationSourceFactoryImpl.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'source' must be private and have accessor methods. 24

org/apache/hadoop/hbase/replication/regionserver/MetricsSource.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 124). 56

org/apache/hadoop/hbase/replication/regionserver/RegionReplicaReplicationEndpoint.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.wal.WALKey. 63
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.wal.WALCellCodec. 67
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.replication.ReplicationEndpoint. 74
 Error design VisibilityModifier Variable 'sink' must be private and have accessor methods. 430
 Error design VisibilityModifier Variable 'connection' must be private and have accessor methods. 431
 Error design VisibilityModifier Variable 'rpcControllerFactory' must be private and have accessor methods. 432
 Error design VisibilityModifier Variable 'rpcRetryingCallerFactory' must be private and have accessor methods. 433
 Error design VisibilityModifier Variable 'operationTimeout' must be private and have accessor methods. 434
 Error design VisibilityModifier Variable 'pool' must be private and have accessor methods. 435
 Error design VisibilityModifier Variable 'disabledAndDroppedTables' must be private and have accessor methods. 436
 Error design VisibilityModifier Variable 'factory' must be private and have accessor methods. 595
 Error design VisibilityModifier Variable 'callable' must be private and have accessor methods. 596
 Error design VisibilityModifier Variable 'timeout' must be private and have accessor methods. 597
 Error sizes LineLength Line is longer than 100 characters (found 102). 656

org/apache/hadoop/hbase/replication/regionserver/ReplicationSink.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 106). 326
 Error coding InnerAssignment Inner assignments should be avoided. 393

org/apache/hadoop/hbase/replication/regionserver/ReplicationSource.java

Severity Category Rule Message Line
 Error sizes MethodLength Method length is 192 lines (max allowed is 150). 256
 Error sizes LineLength Line is longer than 100 characters (found 107). 821
 Error sizes LineLength Line is longer than 100 characters (found 155). 898
 Error sizes LineLength Line is longer than 100 characters (found 158). 906
 Error sizes LineLength Line is longer than 100 characters (found 174). 911

org/apache/hadoop/hbase/replication/regionserver/ReplicationSyncUp.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'hostname' must be private and have accessor methods. 125
 Error design VisibilityModifier Variable 'zkw' must be private and have accessor methods. 126

org/apache/hadoop/hbase/rest/Constants.java

Severity Category Rule Message Line
 Error design InterfaceIsType interfaces should describe a type and hence have methods. 27

org/apache/hadoop/hbase/rest/ExistsResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'cacheControl' must be private and have accessor methods. 37
 Error design VisibilityModifier Variable 'tableResource' must be private and have accessor methods. 44

org/apache/hadoop/hbase/rest/MetricsREST.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.rest.MetricsRESTSource. 25

org/apache/hadoop/hbase/rest/MetricsRESTSourceImpl.java

Severity Category Rule Message Line
 Error misc UpperEll Should use uppercase 'L'. 58
 Error misc UpperEll Should use uppercase 'L'. 60
 Error misc UpperEll Should use uppercase 'L'. 61
 Error misc UpperEll Should use uppercase 'L'. 62
 Error misc UpperEll Should use uppercase 'L'. 65
 Error misc UpperEll Should use uppercase 'L'. 66
 Error misc UpperEll Should use uppercase 'L'. 67
 Error misc UpperEll Should use uppercase 'L'. 68

org/apache/hadoop/hbase/rest/MultiRowResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'tableResource' must be private and have accessor methods. 43
 Error design VisibilityModifier Variable 'versions' must be private and have accessor methods. 44

org/apache/hadoop/hbase/rest/NamespacesInstanceResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'namespace' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'queryTables' must be private and have accessor methods. 62

org/apache/hadoop/hbase/rest/RESTServer.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 73
 Error design VisibilityModifier Variable 'LOG' must be private and have accessor methods. 75
 Error design VisibilityModifier Variable 'REST_CSRF_ENABLED_KEY' must be private and have accessor methods. 77
 Error design VisibilityModifier Variable 'REST_CSRF_ENABLED_DEFAULT' must be private and have accessor methods. 78
 Error design VisibilityModifier Variable 'restCSRFEnabled' must be private and have accessor methods. 79
 Error design VisibilityModifier Variable 'REST_CSRF_CUSTOM_HEADER_KEY' must be private and have accessor methods. 80
 Error design VisibilityModifier Variable 'REST_CSRF_CUSTOM_HEADER_DEFAULT' must be private and have accessor methods. 81
 Error design VisibilityModifier Variable 'REST_CSRF_METHODS_TO_IGNORE_KEY' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'REST_CSRF_METHODS_TO_IGNORE_DEFAULT' must be private and have accessor methods. 83
 Error design VisibilityModifier Variable 'REST_CSRF_BROWSER_USERAGENTS_REGEX_KEY' must be private and have accessor methods. 111
 Error blocks EmptyBlock Must have at least one statement. 197

org/apache/hadoop/hbase/rest/RegionsResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'cacheControl' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'tableResource' must be private and have accessor methods. 58

org/apache/hadoop/hbase/rest/ResourceBase.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'servlet' must be private and have accessor methods. 36
 Error design VisibilityModifier Variable 'accessDeniedClazz' must be private and have accessor methods. 37
 Error blocks EmptyBlock Must have at least one statement. 43

org/apache/hadoop/hbase/rest/RootResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'cacheControl' must be private and have accessor methods. 47

org/apache/hadoop/hbase/rest/RowResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'tableResource' must be private and have accessor methods. 62
 Error design VisibilityModifier Variable 'rowspec' must be private and have accessor methods. 63
 Error misc ArrayTypeStyle Array brackets at illegal position. 283

org/apache/hadoop/hbase/rest/RowSpec.java

Severity Category Rule Message Line
 Error coding InnerAssignment Inner assignments should be avoided. 72
 Error coding InnerAssignment Inner assignments should be avoided. 77
 Error coding InnerAssignment Inner assignments should be avoided. 120
 Error coding InnerAssignment Inner assignments should be avoided. 175

org/apache/hadoop/hbase/rest/ScannerInstanceResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'cacheControl' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'generator' must be private and have accessor methods. 59
 Error design VisibilityModifier Variable 'id' must be private and have accessor methods. 60
 Error design VisibilityModifier Variable 'batch' must be private and have accessor methods. 61

org/apache/hadoop/hbase/rest/ScannerResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'tableResource' must be private and have accessor methods. 55

org/apache/hadoop/hbase/rest/ScannerResultGenerator.java

Severity Category Rule Message Line
 Error whitespace ParenPad ')' is preceded with whitespace. 96

org/apache/hadoop/hbase/rest/SchemaResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'cacheControl' must be private and have accessor methods. 56
 Error design VisibilityModifier Variable 'tableResource' must be private and have accessor methods. 63
 Error blocks EmptyBlock Must have at least one statement. 238

org/apache/hadoop/hbase/rest/StorageClusterStatusResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'cacheControl' must be private and have accessor methods. 47

org/apache/hadoop/hbase/rest/StorageClusterVersionResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'cacheControl' must be private and have accessor methods. 43

org/apache/hadoop/hbase/rest/TableResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'table' must be private and have accessor methods. 50

org/apache/hadoop/hbase/rest/TableScanResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'tableResource' must be private and have accessor methods. 57
 Error design VisibilityModifier Variable 'results' must be private and have accessor methods. 58
 Error design VisibilityModifier Variable 'userRequestedLimit' must be private and have accessor methods. 59
 Error design VisibilityModifier Variable 'count' must be private and have accessor methods. 77
 Error sizes LineLength Line is longer than 100 characters (found 101). 121

org/apache/hadoop/hbase/rest/VersionResource.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'cacheControl' must be private and have accessor methods. 52

org/apache/hadoop/hbase/rest/client/Cluster.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'nodes' must be private and have accessor methods. 36
 Error design VisibilityModifier Variable 'lastHost' must be private and have accessor methods. 38

org/apache/hadoop/hbase/rest/client/RemoteAdmin.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'client' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'accessToken' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'maxRetries' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'sleepTime' must be private and have accessor methods. 54
 Error sizes LineLength Line is longer than 100 characters (found 111). 150

org/apache/hadoop/hbase/rest/client/RemoteHTable.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'client' must be private and have accessor methods. 84
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 85
 Error design VisibilityModifier Variable 'name' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'maxRetries' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'sleepTime' must be private and have accessor methods. 88
 Error whitespace ParenPad '(' is followed by whitespace. 319
 Error whitespace ParenPad ')' is preceded with whitespace. 319
 Error whitespace ParenPad '(' is followed by whitespace. 347
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 389
 Error design VisibilityModifier Variable 'uri' must be private and have accessor methods. 521
 Error design VisibilityModifier Variable 'cache' must be private and have accessor methods. 599

org/apache/hadoop/hbase/rest/model/ScannerModel.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'type' must be private and have accessor methods. 128
 Error design VisibilityModifier Variable 'value' must be private and have accessor methods. 129
 Error design VisibilityModifier Variable 'op' must be private and have accessor methods. 130
 Error design VisibilityModifier Variable 'type' must be private and have accessor methods. 200
 Error design VisibilityModifier Variable 'op' must be private and have accessor methods. 201
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 202
 Error design VisibilityModifier Variable 'value' must be private and have accessor methods. 203
 Error design VisibilityModifier Variable 'filters' must be private and have accessor methods. 204
 Error design VisibilityModifier Variable 'limit' must be private and have accessor methods. 205
 Error design VisibilityModifier Variable 'offset' must be private and have accessor methods. 206
 Error design VisibilityModifier Variable 'family' must be private and have accessor methods. 207
 Error design VisibilityModifier Variable 'qualifier' must be private and have accessor methods. 208
 Error design VisibilityModifier Variable 'ifMissing' must be private and have accessor methods. 209
 Error design VisibilityModifier Variable 'latestVersion' must be private and have accessor methods. 210
 Error design VisibilityModifier Variable 'minColumn' must be private and have accessor methods. 211
 Error design VisibilityModifier Variable 'minColumnInclusive' must be private and have accessor methods. 212
 Error design VisibilityModifier Variable 'maxColumn' must be private and have accessor methods. 213
 Error design VisibilityModifier Variable 'maxColumnInclusive' must be private and have accessor methods. 214
 Error design VisibilityModifier Variable 'dropDependentColumn' must be private and have accessor methods. 215
 Error design VisibilityModifier Variable 'chance' must be private and have accessor methods. 216
 Error design VisibilityModifier Variable 'prefixes' must be private and have accessor methods. 217
 Error design VisibilityModifier Variable 'timestamps' must be private and have accessor methods. 219
 Error sizes LineLength Line is longer than 100 characters (found 101). 759

org/apache/hadoop/hbase/rest/model/TableRegionModel.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 140

org/apache/hadoop/hbase/rest/provider/producer/PlainTextMessageBodyProducer.java

Severity Category Rule Message Line
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 74

org/apache/hadoop/hbase/rsgroup/RSGroupInfoManagerImpl.java

Severity Category Rule Message Line
 Error blocks EmptyBlock Must have at least one statement. 531
 Error sizes LineLength Line is longer than 100 characters (found 107). 610

org/apache/hadoop/hbase/security/AccessDeniedException.java

Severity Category Rule Message Line
 Error whitespace ParenPad '(' is followed by whitespace. 38

org/apache/hadoop/hbase/security/AuthMethod.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'code' must be private and have accessor methods. 37
 Error design VisibilityModifier Variable 'mechanismName' must be private and have accessor methods. 38
 Error design VisibilityModifier Variable 'authenticationMethod' must be private and have accessor methods. 39

org/apache/hadoop/hbase/security/EncryptionUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 42

org/apache/hadoop/hbase/security/HBasePolicyProvider.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 106). 41

org/apache/hadoop/hbase/security/HBaseSaslRpcClient.java

Severity Category Rule Message Line
 Error blocks EmptyBlock Must have at least one statement. 236

org/apache/hadoop/hbase/security/HBaseSaslRpcServer.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 47

org/apache/hadoop/hbase/security/SaslStatus.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'state' must be private and have accessor methods. 29

org/apache/hadoop/hbase/security/SaslUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 29
 Error design VisibilityModifier Variable 'saslQop' must be private and have accessor methods. 41

org/apache/hadoop/hbase/security/SecureBulkLoadUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 26

org/apache/hadoop/hbase/security/SecurityInfo.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 105). 36

org/apache/hadoop/hbase/security/SecurityUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 27

org/apache/hadoop/hbase/security/User.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'ugi' must be private and have accessor methods. 58
 Error design FinalClass Class SecureHadoopUser should be declared as final. 282

org/apache/hadoop/hbase/security/access/AccessControlClient.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 49
 Error sizes LineLength Line is longer than 100 characters (found 105). 199

org/apache/hadoop/hbase/security/access/AccessControlConstants.java

Severity Category Rule Message Line
 Error design InterfaceIsType interfaces should describe a type and hence have methods. 24

org/apache/hadoop/hbase/security/access/AccessControlLists.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 99
 Error misc ArrayTypeStyle Array brackets at illegal position. 705

org/apache/hadoop/hbase/security/access/AccessController.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'authManager' must be private and have accessor methods. 177
 Error design VisibilityModifier Variable 'aclRegion' must be private and have accessor methods. 180
 Error design VisibilityModifier Variable 'authorizationEnabled' must be private and have accessor methods. 197
 Error design VisibilityModifier Variable 'cellFeaturesEnabled' must be private and have accessor methods. 200
 Error design VisibilityModifier Variable 'shouldCheckExecPermission' must be private and have accessor methods. 203
 Error design VisibilityModifier Variable 'compatibleEarlyTermination' must be private and have accessor methods. 207
 Error sizes MethodLength Method length is 167 lines (max allowed is 150). 703
 Error blocks EmptyBlock Must have at least one statement. 1309
 Error blocks EmptyBlock Must have at least one statement. 1341
 Error sizes LineLength Line is longer than 100 characters (found 101). 1356
 Error sizes LineLength Line is longer than 100 characters (found 108). 1386
 Error sizes LineLength Line is longer than 100 characters (found 101). 2044
 Error coding MissingSwitchDefault switch without "default" clause. 2221
 Error coding MissingSwitchDefault switch without "default" clause. 2273
 Error sizes LineLength Line is longer than 100 characters (found 101). 2327
 Error sizes LineLength Line is longer than 100 characters (found 112). 2495

org/apache/hadoop/hbase/security/access/AuthResult.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'family' must be private and have accessor methods. 254
 Error design VisibilityModifier Variable 'qualifier' must be private and have accessor methods. 255

org/apache/hadoop/hbase/security/access/CodeToClassAndBackFor96Migration.java

Severity Category Rule Message Line
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 22
 Error design InterfaceIsType interfaces should describe a type and hence have methods. 36

org/apache/hadoop/hbase/security/access/CoprocessorWhitelistMasterObserver.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.net.URI. 22
 Error imports UnusedImports Unused import - java.nio.file.PathMatcher. 23

org/apache/hadoop/hbase/security/access/HbaseObjectWritableFor96Migration.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'declaredClass' must be private and have accessor methods. 350
 Error whitespace ParenPad ')' is preceded with whitespace. 376
 Error sizes LineLength Line is longer than 100 characters (found 111). 395
 Error blocks EmptyBlock Must have at least one statement. 497

org/apache/hadoop/hbase/security/access/Permission.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'actions' must be private and have accessor methods. 62
 Error misc ArrayTypeStyle Array brackets at illegal position. 83

org/apache/hadoop/hbase/security/access/SecureBulkLoadEndpoint.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 108). 128
 Error sizes LineLength Line is longer than 100 characters (found 101). 518
 Error blocks EmptyBlock Must have at least one statement. 519

org/apache/hadoop/hbase/security/access/TableAuthManager.java

Severity Category Rule Message Line
 Error design FinalClass Class TableAuthManager should be declared as final. 49
 Error design VisibilityModifier Variable 'managerMap' must be private and have accessor methods. 741

org/apache/hadoop/hbase/security/access/ZKPermissionWatcher.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'authManager' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'aclZNode' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'initialized' must be private and have accessor methods. 52

org/apache/hadoop/hbase/security/token/AuthenticationTokenIdentifier.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'username' must be private and have accessor methods. 40
 Error design VisibilityModifier Variable 'keyId' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'issueDate' must be private and have accessor methods. 42
 Error design VisibilityModifier Variable 'expirationDate' must be private and have accessor methods. 43
 Error design VisibilityModifier Variable 'sequenceNumber' must be private and have accessor methods. 44

org/apache/hadoop/hbase/security/token/AuthenticationTokenSecretManager.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 103). 85
 Error sizes LineLength Line is longer than 100 characters (found 104). 86

org/apache/hadoop/hbase/security/token/TokenProvider.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 109). 103

org/apache/hadoop/hbase/security/token/TokenUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 53
 Error sizes LineLength Line is longer than 100 characters (found 105). 86

org/apache/hadoop/hbase/security/visibility/DefaultVisibilityLabelServiceImpl.java

Severity Category Rule Message Line
 Error blocks EmptyBlock Must have at least one statement. 90
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 322
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 541

org/apache/hadoop/hbase/security/visibility/ExpressionParser.java

Severity Category Rule Message Line
 Error coding MissingSwitchDefault switch without "default" clause. 300

org/apache/hadoop/hbase/security/visibility/VisibilityClient.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 28 - org.apache.hadoop.hbase.client.Table. 34
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 54
 Error design VisibilityModifier Variable 'controller' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'rpcCallback' must be private and have accessor methods. 88
 Error design VisibilityModifier Variable 'controller' must be private and have accessor methods. 144
 Error design VisibilityModifier Variable 'rpcCallback' must be private and have accessor methods. 145
 Error design VisibilityModifier Variable 'controller' must be private and have accessor methods. 184
 Error design VisibilityModifier Variable 'rpcCallback' must be private and have accessor methods. 185
 Error design VisibilityModifier Variable 'controller' must be private and have accessor methods. 240
 Error design VisibilityModifier Variable 'rpcCallback' must be private and have accessor methods. 241

org/apache/hadoop/hbase/security/visibility/VisibilityConstants.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 25

org/apache/hadoop/hbase/security/visibility/VisibilityController.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'authorizationEnabled' must be private and have accessor methods. 141
 Error sizes LineLength Line is longer than 100 characters (found 101). 185
 Error sizes LineLength Line is longer than 100 characters (found 102). 195
 Error sizes LineLength Line is longer than 100 characters (found 101). 250
 Error sizes LineLength Line is longer than 100 characters (found 108). 759
 Error blocks EmptyBlock Must have at least one statement. 1049
 Error sizes LineLength Line is longer than 100 characters (found 101). 1085

org/apache/hadoop/hbase/security/visibility/VisibilityLabelService.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.TagType. 25

org/apache/hadoop/hbase/security/visibility/VisibilityLabelServiceManager.java

Severity Category Rule Message Line
 Error design FinalClass Class VisibilityLabelServiceManager should be declared as final. 31

org/apache/hadoop/hbase/security/visibility/VisibilityLabelsCache.java

Severity Category Rule Message Line
 Error design FinalClass Class VisibilityLabelsCache should be declared as final. 48

org/apache/hadoop/hbase/security/visibility/VisibilityLabelsValidator.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 27

org/apache/hadoop/hbase/security/visibility/VisibilityReplicationEndpoint.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 104). 60
 Error sizes LineLength Line is longer than 100 characters (found 101). 61
 Error sizes LineLength Line is longer than 100 characters (found 104). 85

org/apache/hadoop/hbase/security/visibility/VisibilityUtils.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 69

org/apache/hadoop/hbase/snapshot/ClientSnapshotDescriptionUtils.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 31
 Error sizes LineLength Line is longer than 100 characters (found 148). 55

org/apache/hadoop/hbase/snapshot/ExportSnapshot.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.HFile. 54
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.mapreduce.JobUtil. 55
 Error blocks EmptyBlock Must have at least one statement. 546
 Error whitespace MethodParamPad '(' is preceded with whitespace. 569
 Error sizes MethodLength Method length is 175 lines (max allowed is 150). 867
 Error sizes LineLength Line is longer than 100 characters (found 102). 946

org/apache/hadoop/hbase/snapshot/SnapshotDescriptionUtils.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.classification.InterfaceAudience. 36
 Error design FinalClass Class SnapshotDescriptionUtils should be declared as final. 83
 Error sizes LineLength Line is longer than 100 characters (found 101). 118
 Error sizes LineLength Line is longer than 100 characters (found 102). 178

org/apache/hadoop/hbase/snapshot/SnapshotInfo.java

Severity Category Rule Message Line
 Error coding InnerAssignment Inner assignments should be avoided. 235
 Error coding InnerAssignment Inner assignments should be avoided. 239
 Error whitespace MethodParamPad '(' is preceded with whitespace. 436
 Error sizes LineLength Line is longer than 100 characters (found 102). 464
 Error whitespace MethodParamPad '(' is preceded with whitespace. 523

org/apache/hadoop/hbase/snapshot/SnapshotManifest.java

Severity Category Rule Message Line
 Error design FinalClass Class SnapshotManifest should be declared as final. 69

org/apache/hadoop/hbase/snapshot/SnapshotManifestV1.java

Severity Category Rule Message Line
 Error design FinalClass Class SnapshotManifestV1 should be declared as final. 56
 Error whitespace MethodParamPad '(' is preceded with whitespace. 157

org/apache/hadoop/hbase/snapshot/SnapshotManifestV2.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 56

org/apache/hadoop/hbase/snapshot/SnapshotReferenceUtil.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.FSUtils. 47
 Error whitespace MethodParamPad '(' is preceded with whitespace. 385

org/apache/hadoop/hbase/spark/SparkSQLPushDownFilter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'dynamicLogicExpression' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'valueFromQueryArray' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'currentCellToColumnIndexMap' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'columnToCurrentRowValueMap' must be private and have accessor methods. 57
 Error design VisibilityModifier Variable 'encoderClassName' must be private and have accessor methods. 62

org/apache/hadoop/hbase/thrift/CallQueue.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'startTime' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'underlyingRunnable' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'underlyingIterator' must be private and have accessor methods. 205

org/apache/hadoop/hbase/thrift/DemoClient.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'port' must be private and have accessor methods. 58
 Error design VisibilityModifier Variable 'host' must be private and have accessor methods. 59
 Error design VisibilityModifier Variable 'decoder' must be private and have accessor methods. 60
 Error sizes MethodLength Method length is 223 lines (max allowed is 150). 114
 Error sizes LineLength Line is longer than 100 characters (found 102). 177
 Error sizes LineLength Line is longer than 100 characters (found 123). 179
 Error sizes LineLength Line is longer than 100 characters (found 116). 206
 Error sizes LineLength Line is longer than 100 characters (found 118). 212
 Error sizes LineLength Line is longer than 100 characters (found 119). 221
 Error sizes LineLength Line is longer than 100 characters (found 131). 242
 Error blocks EmptyBlock Must have at least one statement. 250
 Error sizes LineLength Line is longer than 100 characters (found 125). 255
 Error sizes LineLength Line is longer than 100 characters (found 127). 256
 Error sizes LineLength Line is longer than 100 characters (found 141). 274
 Error sizes LineLength Line is longer than 100 characters (found 145). 275
 Error blocks EmptyBlock Must have at least one statement. 282
 Error sizes LineLength Line is longer than 100 characters (found 133). 294
 Error sizes LineLength Line is longer than 100 characters (found 149). 297
 Error sizes LineLength Line is longer than 100 characters (found 140). 304
 Error sizes LineLength Line is longer than 100 characters (found 161). 324

org/apache/hadoop/hbase/thrift/HbaseHandlerMetricsProxy.java

Severity Category Rule Message Line
 Error design FinalClass Class HbaseHandlerMetricsProxy should be declared as final. 37

org/apache/hadoop/hbase/thrift/HttpDoAsClient.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'port' must be private and have accessor methods. 63
 Error design VisibilityModifier Variable 'host' must be private and have accessor methods. 64
 Error design VisibilityModifier Variable 'decoder' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'doAsUser' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'principal' must be private and have accessor methods. 68
 Error sizes LineLength Line is longer than 100 characters (found 117). 178

org/apache/hadoop/hbase/thrift/IncrementCoalescer.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'group' must be private and have accessor methods. 135
 Error design VisibilityModifier Variable 'threadNumber' must be private and have accessor methods. 136
 Error design VisibilityModifier Variable 'namePrefix' must be private and have accessor methods. 137
 Error design VisibilityModifier Variable 'LOG' must be private and have accessor methods. 164
 Error blocks EmptyBlock Must have at least one statement. 306

org/apache/hadoop/hbase/thrift/MetricsThriftServerSourceFactory.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 103). 21

org/apache/hadoop/hbase/thrift/MetricsThriftServerSourceFactoryImpl.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'thriftOne' must be private and have accessor methods. 35
 Error design VisibilityModifier Variable 'thriftTwo' must be private and have accessor methods. 39

org/apache/hadoop/hbase/thrift/MetricsThriftServerSourceImpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 112). 28

org/apache/hadoop/hbase/thrift/TBoundedThreadPoolServer.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'maxQueuedRequests' must be private and have accessor methods. 111
 Error design VisibilityModifier Variable 'threadKeepAliveTimeSec' must be private and have accessor methods. 112
 Error design FinalClass Class ClientConnnection should be declared as final. 259
 Error blocks EmptyBlock Must have at least one statement. 289
 Error blocks EmptyBlock Must have at least one statement. 290

org/apache/hadoop/hbase/thrift/ThriftHttpServlet.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'request' must be private and have accessor methods. 145
 Error design VisibilityModifier Variable 'serviceUGI' must be private and have accessor methods. 146
 Error design VisibilityModifier Variable 'outToken' must be private and have accessor methods. 147

org/apache/hadoop/hbase/thrift/ThriftMetrics.java

Severity Category Rule Message Line
 Error whitespace ParenPad '(' is followed by whitespace. 55
 Error sizes LineLength Line is longer than 100 characters (found 121). 58
 Error sizes LineLength Line is longer than 100 characters (found 121). 60

org/apache/hadoop/hbase/thrift/ThriftServer.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'serverRunner' must be private and have accessor methods. 63

org/apache/hadoop/hbase/thrift/ThriftServerRunner.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 104). 152
 Error design VisibilityModifier Variable 'tserver' must be private and have accessor methods. 183
 Error design VisibilityModifier Variable 'httpServer' must be private and have accessor methods. 184
 Error design VisibilityModifier Variable 'option' must be private and have accessor methods. 206
 Error design VisibilityModifier Variable 'isAlwaysFramed' must be private and have accessor methods. 207
 Error design VisibilityModifier Variable 'serverClass' must be private and have accessor methods. 208
 Error design VisibilityModifier Variable 'canSpecifyBindIP' must be private and have accessor methods. 209
 Error sizes MethodLength Method length is 162 lines (max allowed is 150). 432
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 634
 Error design VisibilityModifier Variable 'LOG' must be private and have accessor methods. 635
 Error design VisibilityModifier Variable 'nextScannerId' must be private and have accessor methods. 638
 Error design VisibilityModifier Variable 'scannerMap' must be private and have accessor methods. 639
 Error design VisibilityModifier Variable 'coalescer' must be private and have accessor methods. 643
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 845
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 893
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 940
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1359
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 1661

org/apache/hadoop/hbase/thrift/ThriftUtilities.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 47
 Error whitespace ParenPad '(' is followed by whitespace. 151

org/apache/hadoop/hbase/thrift2/DemoClient.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 120). 55

org/apache/hadoop/hbase/thrift2/ThriftHBaseServiceHandler.java

Severity Category Rule Message Line
 Error design FinalClass Class THBaseServiceMetricsProxy should be declared as final. 100

org/apache/hadoop/hbase/thrift2/ThriftServer.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 102). 89
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 92
 Error sizes LineLength Line is longer than 100 characters (found 108). 135
 Error sizes LineLength Line is longer than 100 characters (found 108). 136
 Error sizes LineLength Line is longer than 100 characters (found 106). 137
 Error sizes LineLength Line is longer than 100 characters (found 102). 223
 Error sizes LineLength Line is longer than 100 characters (found 107). 224
 Error sizes LineLength Line is longer than 100 characters (found 101). 261
 Error sizes LineLength Line is longer than 100 characters (found 107). 262
 Error sizes MethodLength Method length is 162 lines (max allowed is 150). 296
 Error sizes LineLength Line is longer than 100 characters (found 118). 303
 Error sizes LineLength Line is longer than 100 characters (found 102). 441
 Error sizes LineLength Line is longer than 100 characters (found 104). 443
 Error sizes LineLength Line is longer than 100 characters (found 101). 445

org/apache/hadoop/hbase/thrift2/ThriftUtilities.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.HRegionLocator. 40
 Error design FinalClass Class ThriftUtilities should be declared as final. 70

org/apache/hadoop/hbase/tmpl/common/TaskMonitorTmpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 149). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - org.apache.hadoop.hbase.monitoring.*. 9
 Error imports UnusedImports Unused import - org.apache.hadoop.util.StringUtils. 11
 Error design VisibilityModifier Variable 'format' must be private and have accessor methods. 110
 Error design VisibilityModifier Variable 'taskMonitor' must be private and have accessor methods. 117
 Error sizes LineLength Line is longer than 100 characters (found 108). 118
 Error design VisibilityModifier Variable 'filter' must be private and have accessor methods. 124
 Error sizes LineLength Line is longer than 100 characters (found 111). 133

org/apache/hadoop/hbase/tmpl/common/TaskMonitorTmplImpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 149). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - org.apache.hadoop.hbase.monitoring.*. 9
 Error sizes LineLength Line is longer than 100 characters (found 181). 21
 Error sizes LineLength Line is longer than 100 characters (found 146). 37
 Error sizes MethodLength Method length is 160 lines (max allowed is 150). 45
 Error sizes LineLength Line is longer than 100 characters (found 115). 96
 Error sizes LineLength Line is longer than 100 characters (found 106). 147
 Error sizes LineLength Line is longer than 100 characters (found 186). 160
 Error whitespace ParenPad ')' is preceded with whitespace. 162
 Error whitespace ParenPad ')' is preceded with whitespace. 169
 Error sizes LineLength Line is longer than 100 characters (found 133). 174
 Error sizes LineLength Line is longer than 100 characters (found 125). 178
 Error sizes LineLength Line is longer than 100 characters (found 119). 182
 Error sizes LineLength Line is longer than 100 characters (found 156). 186
 Error sizes LineLength Line is longer than 100 characters (found 120). 190
 Error sizes LineLength Line is longer than 100 characters (found 157). 194
 Error sizes LineLength Line is longer than 100 characters (found 109). 210

org/apache/hadoop/hbase/tmpl/master/AssignmentManagerStatusTmpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 161). 2
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HRegionInfo. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.master.RegionState. 11
 Error imports UnusedImports Unused import - org.apache.hadoop.conf.Configuration. 13
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseConfiguration. 15
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HConstants. 17
 Error imports UnusedImports Unused import - java.util.Iterator. 19
 Error imports UnusedImports Unused import - java.util.Map. 21
 Error design VisibilityModifier Variable 'limit' must be private and have accessor methods. 97
 Error sizes LineLength Line is longer than 100 characters (found 111). 106
 Error sizes LineLength Line is longer than 100 characters (found 104). 145

org/apache/hadoop/hbase/tmpl/master/AssignmentManagerStatusTmplImpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 161). 2
 Error sizes LineLength Line is longer than 100 characters (found 205). 30
 Error sizes LineLength Line is longer than 100 characters (found 170). 38
 Error whitespace ParenPad ')' is preceded with whitespace. 92
 Error sizes LineLength Line is longer than 100 characters (found 210). 95
 Error whitespace ParenPad ')' is preceded with whitespace. 97
 Error whitespace ParenPad ')' is preceded with whitespace. 102
 Error sizes LineLength Line is longer than 100 characters (found 116). 116
 Error sizes LineLength Line is longer than 100 characters (found 140). 120
 Error sizes LineLength Line is longer than 100 characters (found 145). 124
 Error sizes LineLength Line is longer than 100 characters (found 123). 129
 Error sizes LineLength Line is longer than 100 characters (found 112). 131
 Error sizes LineLength Line is longer than 100 characters (found 121). 135
 Error sizes LineLength Line is longer than 100 characters (found 123). 137
 Error sizes LineLength Line is longer than 100 characters (found 110). 139
 Error whitespace ParenPad ')' is preceded with whitespace. 143
 Error sizes LineLength Line is longer than 100 characters (found 109). 148

org/apache/hadoop/hbase/tmpl/master/BackupMasterStatusTmpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 156). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ServerName. 9
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ClusterStatus. 11
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.zookeeper.MasterAddressTracker. 15
 Error sizes LineLength Line is longer than 100 characters (found 111). 74

org/apache/hadoop/hbase/tmpl/master/BackupMasterStatusTmplImpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 156). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error sizes LineLength Line is longer than 100 characters (found 195). 23
 Error sizes LineLength Line is longer than 100 characters (found 160). 27
 Error whitespace ParenPad ')' is preceded with whitespace. 56
 Error whitespace ParenPad ')' is preceded with whitespace. 61
 Error sizes LineLength Line is longer than 100 characters (found 130). 66
 Error sizes LineLength Line is longer than 100 characters (found 110). 70
 Error sizes LineLength Line is longer than 100 characters (found 130). 74
 Error sizes LineLength Line is longer than 100 characters (found 210). 91
 Error sizes LineLength Line is longer than 100 characters (found 109). 96
 Error sizes LineLength Line is longer than 100 characters (found 124). 101
 Error sizes LineLength Line is longer than 100 characters (found 108). 105
 Error sizes LineLength Line is longer than 100 characters (found 124). 109
 Error sizes LineLength Line is longer than 100 characters (found 120). 113
 Error sizes LineLength Line is longer than 100 characters (found 135). 117
 Error sizes LineLength Line is longer than 100 characters (found 138). 127

org/apache/hadoop/hbase/tmpl/master/MasterStatusTmpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 150). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseConfiguration. 9
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HConstants. 11
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HRegionInfo. 13
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HTableDescriptor. 15
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.NamespaceDescriptor. 17
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ServerLoad. 19
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.Admin. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.HConnectionManager. 25
 Error imports RedundantImport Duplicate import to line 13 - org.apache.hadoop.hbase.HRegionInfo. 27
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HRegionInfo. 27
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.master.RegionState. 29
 Error imports RedundantImport Duplicate import to line 15 - org.apache.hadoop.hbase.HTableDescriptor. 31
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HTableDescriptor. 31
 Error imports RedundantImport Duplicate import to line 9 - org.apache.hadoop.hbase.HBaseConfiguration. 33
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseConfiguration. 33
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.TableName. 35
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription. 37
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.master.DeadServer. 41
 Error imports RedundantImport Duplicate import to line 29 - org.apache.hadoop.hbase.master.RegionState. 45
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.master.RegionState. 45
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.ProtobufUtil. 49
 Error imports RedundantImport Duplicate import to line 37 - org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription. 51
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription. 51
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.quotas.QuotaUtil. 53
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.access.AccessControlLists. 55
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.security.visibility.VisibilityConstants. 57
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.tool.Canary. 59
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.Bytes. 61
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.FSUtils. 63
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.JvmVersion. 65
 Error imports UnusedImports Unused import - org.apache.hadoop.util.StringUtils. 67
 Error design VisibilityModifier Variable 'serverManager' must be private and have accessor methods. 287
 Error sizes LineLength Line is longer than 100 characters (found 115). 288
 Error design VisibilityModifier Variable 'metaLocation' must be private and have accessor methods. 294
 Error sizes LineLength Line is longer than 100 characters (found 110). 295
 Error design VisibilityModifier Variable 'catalogJanitorEnabled' must be private and have accessor methods. 301
 Error sizes LineLength Line is longer than 100 characters (found 125). 302
 Error design VisibilityModifier Variable 'assignmentManager' must be private and have accessor methods. 308
 Error sizes LineLength Line is longer than 100 characters (found 127). 309
 Error design VisibilityModifier Variable 'deadServers' must be private and have accessor methods. 315
 Error sizes LineLength Line is longer than 100 characters (found 113). 316
 Error design VisibilityModifier Variable 'filter' must be private and have accessor methods. 322
 Error design VisibilityModifier Variable 'servers' must be private and have accessor methods. 329
 Error sizes LineLength Line is longer than 100 characters (found 106). 330
 Error design VisibilityModifier Variable 'format' must be private and have accessor methods. 336
 Error design VisibilityModifier Variable 'frags' must be private and have accessor methods. 343
 Error sizes LineLength Line is longer than 100 characters (found 105). 344
 Error sizes LineLength Line is longer than 100 characters (found 111). 352

org/apache/hadoop/hbase/tmpl/master/MasterStatusTmplImpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 150). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HConstants. 11
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ServerLoad. 19
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.HConnectionManager. 25
 Error imports RedundantImport Duplicate import to line 13 - org.apache.hadoop.hbase.HRegionInfo. 27
 Error imports RedundantImport Duplicate import to line 15 - org.apache.hadoop.hbase.HTableDescriptor. 31
 Error imports RedundantImport Duplicate import to line 9 - org.apache.hadoop.hbase.HBaseConfiguration. 33
 Error imports RedundantImport Duplicate import to line 29 - org.apache.hadoop.hbase.master.RegionState. 45
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.ProtobufUtil. 49
 Error imports RedundantImport Duplicate import to line 37 - org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription. 51
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.tool.Canary. 59
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.Bytes. 61
 Error sizes LineLength Line is longer than 100 characters (found 183). 111
 Error sizes LineLength Line is longer than 100 characters (found 148). 151
 Error sizes MethodLength Method length is 293 lines (max allowed is 150). 166
 Error whitespace ParenPad ')' is preceded with whitespace. 170
 Error sizes LineLength Line is longer than 100 characters (found 160). 176
 Error whitespace ParenPad ')' is preceded with whitespace. 177
 Error sizes LineLength Line is longer than 100 characters (found 195). 194
 Error sizes LineLength Line is longer than 100 characters (found 134). 196
 Error sizes LineLength Line is longer than 100 characters (found 155). 206
 Error whitespace ParenPad ')' is preceded with whitespace. 208
 Error sizes LineLength Line is longer than 100 characters (found 147). 211
 Error sizes LineLength Line is longer than 100 characters (found 136). 213
 Error sizes LineLength Line is longer than 100 characters (found 193). 215
 Error whitespace ParenPad ')' is preceded with whitespace. 217
 Error sizes LineLength Line is longer than 100 characters (found 112). 220
 Error sizes LineLength Line is longer than 100 characters (found 136). 222
 Error whitespace ParenPad ')' is preceded with whitespace. 229
 Error sizes LineLength Line is longer than 100 characters (found 294). 232
 Error whitespace ParenPad ')' is preceded with whitespace. 237
 Error sizes LineLength Line is longer than 100 characters (found 378). 240
 Error sizes LineLength Line is longer than 100 characters (found 170). 246
 Error whitespace ParenPad ')' is preceded with whitespace. 247
 Error whitespace ParenPad ')' is preceded with whitespace. 253
 Error sizes LineLength Line is longer than 100 characters (found 174). 269
 Error whitespace ParenPad ')' is preceded with whitespace. 270
 Error whitespace ParenPad ')' is preceded with whitespace. 275
 Error sizes LineLength Line is longer than 100 characters (found 153). 288
 Error whitespace ParenPad ')' is preceded with whitespace. 290
 Error sizes LineLength Line is longer than 100 characters (found 153). 303
 Error sizes LineLength Line is longer than 100 characters (found 130). 310
 Error whitespace ParenPad ')' is preceded with whitespace. 312
 Error sizes LineLength Line is longer than 100 characters (found 186). 318
 Error sizes LineLength Line is longer than 100 characters (found 174). 334
 Error whitespace ParenPad ')' is preceded with whitespace. 335
 Error sizes LineLength Line is longer than 100 characters (found 158). 344
 Error whitespace ParenPad ')' is preceded with whitespace. 345
 Error sizes LineLength Line is longer than 100 characters (found 444). 349
 Error sizes LineLength Line is longer than 100 characters (found 151). 351
 Error sizes LineLength Line is longer than 100 characters (found 152). 355
 Error sizes LineLength Line is longer than 100 characters (found 182). 357
 Error sizes LineLength Line is longer than 100 characters (found 148). 359
 Error sizes LineLength Line is longer than 100 characters (found 148). 363
 Error sizes LineLength Line is longer than 100 characters (found 228). 365
 Error sizes LineLength Line is longer than 100 characters (found 155). 367
 Error sizes LineLength Line is longer than 100 characters (found 203). 369
 Error sizes LineLength Line is longer than 100 characters (found 145). 371
 Error sizes LineLength Line is longer than 100 characters (found 146). 375
 Error sizes LineLength Line is longer than 100 characters (found 206). 377
 Error sizes LineLength Line is longer than 100 characters (found 142). 379
 Error sizes LineLength Line is longer than 100 characters (found 142). 383
 Error sizes LineLength Line is longer than 100 characters (found 230). 385
 Error sizes LineLength Line is longer than 100 characters (found 149). 387
 Error sizes LineLength Line is longer than 100 characters (found 214). 389
 Error sizes LineLength Line is longer than 100 characters (found 139). 391
 Error sizes LineLength Line is longer than 100 characters (found 140). 395
 Error sizes LineLength Line is longer than 100 characters (found 226). 397
 Error sizes LineLength Line is longer than 100 characters (found 141). 399
 Error sizes LineLength Line is longer than 100 characters (found 223). 401
 Error sizes LineLength Line is longer than 100 characters (found 114). 403
 Error sizes LineLength Line is longer than 100 characters (found 134). 407
 Error sizes LineLength Line is longer than 100 characters (found 216). 409
 Error sizes LineLength Line is longer than 100 characters (found 154). 411
 Error sizes LineLength Line is longer than 100 characters (found 214). 413
 Error sizes LineLength Line is longer than 100 characters (found 135). 415
 Error sizes LineLength Line is longer than 100 characters (found 146). 417
 Error whitespace ParenPad ')' is preceded with whitespace. 419
 Error sizes LineLength Line is longer than 100 characters (found 132). 422
 Error sizes LineLength Line is longer than 100 characters (found 138). 424
 Error sizes LineLength Line is longer than 100 characters (found 237). 426
 Error sizes LineLength Line is longer than 100 characters (found 165). 428
 Error sizes LineLength Line is longer than 100 characters (found 238). 430
 Error sizes LineLength Line is longer than 100 characters (found 128). 432
 Error sizes LineLength Line is longer than 100 characters (found 117). 433
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 433
 Error sizes LineLength Line is longer than 100 characters (found 173). 435
 Error whitespace ParenPad ')' is preceded with whitespace. 437
 Error sizes LineLength Line is longer than 100 characters (found 128). 440
 Error sizes LineLength Line is longer than 100 characters (found 178). 442
 Error sizes LineLength Line is longer than 100 characters (found 170). 444
 Error sizes LineLength Line is longer than 100 characters (found 125). 447
 Error sizes LineLength Line is longer than 100 characters (found 134). 449
 Error sizes LineLength Line is longer than 100 characters (found 103). 450
 Error sizes LineLength Line is longer than 100 characters (found 231). 452
 Error sizes LineLength Line is longer than 100 characters (found 133). 454
 Error sizes LineLength Line is longer than 100 characters (found 146). 456
 Error sizes LineLength Line is longer than 100 characters (found 381). 459
 Error sizes LineLength Line is longer than 100 characters (found 200). 471
 Error sizes LineLength Line is longer than 100 characters (found 114). 482
 Error sizes LineLength Line is longer than 100 characters (found 145). 486
 Error sizes LineLength Line is longer than 100 characters (found 118). 496
 Error sizes LineLength Line is longer than 100 characters (found 104). 521
 Error whitespace ParenPad ')' is preceded with whitespace. 523
 Error sizes LineLength Line is longer than 100 characters (found 157). 526
 Error sizes LineLength Line is longer than 100 characters (found 111). 540
 Error sizes LineLength Line is longer than 100 characters (found 111). 544
 Error sizes LineLength Line is longer than 100 characters (found 175). 553
 Error sizes LineLength Line is longer than 100 characters (found 113). 580
 Error sizes LineLength Line is longer than 100 characters (found 182). 607
 Error sizes LineLength Line is longer than 100 characters (found 124). 620
 Error sizes LineLength Line is longer than 100 characters (found 124). 624
 Error sizes LineLength Line is longer than 100 characters (found 133). 628
 Error sizes LineLength Line is longer than 100 characters (found 133). 632
 Error sizes LineLength Line is longer than 100 characters (found 142). 636
 Error sizes LineLength Line is longer than 100 characters (found 116). 643
 Error sizes LineLength Line is longer than 100 characters (found 144). 667
 Error whitespace ParenPad ')' is preceded with whitespace. 669
 Error sizes LineLength Line is longer than 100 characters (found 165). 672
 Error sizes LineLength Line is longer than 100 characters (found 239). 675
 Error sizes LineLength Line is longer than 100 characters (found 146). 703
 Error sizes LineLength Line is longer than 100 characters (found 141). 707
 Error sizes LineLength Line is longer than 100 characters (found 146). 711
 Error whitespace ParenPad ')' is preceded with whitespace. 715
 Error sizes LineLength Line is longer than 100 characters (found 245). 720
 Error sizes LineLength Line is longer than 100 characters (found 118). 727
 Error sizes LineLength Line is longer than 100 characters (found 121). 731
 Error sizes LineLength Line is longer than 100 characters (found 120). 735
 Error sizes LineLength Line is longer than 100 characters (found 119). 739
 Error sizes LineLength Line is longer than 100 characters (found 119). 743
 Error sizes LineLength Line is longer than 100 characters (found 135). 747
 Error sizes LineLength Line is longer than 100 characters (found 113). 754

org/apache/hadoop/hbase/tmpl/master/RegionServerListTmpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 154). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ServerLoad. 11
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.HBaseAdmin. 15
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.HConnectionManager. 17
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HTableDescriptor. 19
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseConfiguration. 21
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.VersionInfo. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.util.StringUtils.TraditionalBinaryPrefix. 25
 Error design VisibilityModifier Variable 'servers' must be private and have accessor methods. 101
 Error sizes LineLength Line is longer than 100 characters (found 110). 102
 Error sizes LineLength Line is longer than 100 characters (found 111). 110

org/apache/hadoop/hbase/tmpl/master/RegionServerListTmplImpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 154). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.HBaseAdmin. 15
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.HConnectionManager. 17
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HTableDescriptor. 19
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseConfiguration. 21
 Error sizes LineLength Line is longer than 100 characters (found 191). 34
 Error sizes LineLength Line is longer than 100 characters (found 156). 42
 Error sizes LineLength Line is longer than 100 characters (found 115). 70
 Error sizes LineLength Line is longer than 100 characters (found 116). 77
 Error sizes LineLength Line is longer than 100 characters (found 114). 84
 Error sizes LineLength Line is longer than 100 characters (found 115). 91
 Error sizes LineLength Line is longer than 100 characters (found 140). 106
 Error sizes LineLength Line is longer than 100 characters (found 103). 120
 Error sizes LineLength Line is longer than 100 characters (found 126). 124
 Error sizes LineLength Line is longer than 100 characters (found 126). 134
 Error sizes LineLength Line is longer than 100 characters (found 110). 144
 Error sizes LineLength Line is longer than 100 characters (found 280). 148
 Error sizes LineLength Line is longer than 100 characters (found 112). 166
 Error sizes LineLength Line is longer than 100 characters (found 116). 170
 Error sizes LineLength Line is longer than 100 characters (found 118). 174
 Error sizes LineLength Line is longer than 100 characters (found 143). 179
 Error sizes LineLength Line is longer than 100 characters (found 148). 184
 Error sizes LineLength Line is longer than 100 characters (found 148). 189
 Error sizes LineLength Line is longer than 100 characters (found 112). 215
 Error sizes LineLength Line is longer than 100 characters (found 203). 219
 Error sizes LineLength Line is longer than 100 characters (found 146). 237
 Error sizes LineLength Line is longer than 100 characters (found 123). 241
 Error sizes LineLength Line is longer than 100 characters (found 124). 245
 Error sizes LineLength Line is longer than 100 characters (found 111). 270
 Error sizes LineLength Line is longer than 100 characters (found 180). 274
 Error sizes LineLength Line is longer than 100 characters (found 136). 292
 Error sizes LineLength Line is longer than 100 characters (found 135). 297
 Error sizes LineLength Line is longer than 100 characters (found 142). 302
 Error sizes LineLength Line is longer than 100 characters (found 115). 328
 Error sizes LineLength Line is longer than 100 characters (found 232). 332
 Error sizes LineLength Line is longer than 100 characters (found 124). 355
 Error sizes LineLength Line is longer than 100 characters (found 125). 359
 Error sizes LineLength Line is longer than 100 characters (found 154). 363
 Error sizes LineLength Line is longer than 100 characters (found 109). 367
 Error sizes LineLength Line is longer than 100 characters (found 109). 392
 Error sizes LineLength Line is longer than 100 characters (found 211). 396
 Error sizes LineLength Line is longer than 100 characters (found 117). 433
 Error sizes LineLength Line is longer than 100 characters (found 105). 437
 Error sizes LineLength Line is longer than 100 characters (found 138). 441
 Error sizes LineLength Line is longer than 100 characters (found 114). 445
 Error sizes LineLength Line is longer than 100 characters (found 112). 455
 Error sizes LineLength Line is longer than 100 characters (found 119). 464
 Error sizes LineLength Line is longer than 100 characters (found 111). 477
 Error sizes LineLength Line is longer than 100 characters (found 110). 481
 Error sizes LineLength Line is longer than 100 characters (found 106). 488
 Error sizes LineLength Line is longer than 100 characters (found 134). 499

org/apache/hadoop/hbase/tmpl/regionserver/BlockCacheTmpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 154). 2
 Error imports UnusedImports Unused import - java.util.Map. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile. 9
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.AgeSnapshot. 11
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.CachedBlock. 13
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.BlockCache. 19
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats. 21
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketCache. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator. 25
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket. 27
 Error imports UnusedImports Unused import - org.apache.hadoop.util.StringUtils.TraditionalBinaryPrefix. 29
 Error sizes LineLength Line is longer than 100 characters (found 111). 100
 Error sizes LineLength Line is longer than 100 characters (found 113). 133
 Error sizes LineLength Line is longer than 100 characters (found 120). 139

org/apache/hadoop/hbase/tmpl/regionserver/BlockCacheTmplImpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 154). 2
 Error imports UnusedImports Unused import - java.util.Map. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile. 9
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.CachedBlock. 13
 Error sizes LineLength Line is longer than 100 characters (found 191). 38
 Error sizes LineLength Line is longer than 100 characters (found 150). 42
 Error sizes LineLength Line is longer than 100 characters (found 137). 61
 Error sizes LineLength Line is longer than 100 characters (found 111). 73
 Error whitespace ParenPad ')' is preceded with whitespace. 77
 Error sizes LineLength Line is longer than 100 characters (found 110). 80
 Error whitespace ParenPad ')' is preceded with whitespace. 84
 Error sizes LineLength Line is longer than 100 characters (found 107). 87
 Error sizes LineLength Line is longer than 100 characters (found 107). 94
 Error sizes LineLength Line is longer than 100 characters (found 110). 98
 Error sizes LineLength Line is longer than 100 characters (found 137). 106
 Error whitespace ParenPad ')' is preceded with whitespace. 110
 Error sizes LineLength Line is longer than 100 characters (found 104). 115
 Error sizes LineLength Line is longer than 100 characters (found 144). 138
 Error sizes MethodLength Method length is 160 lines (max allowed is 150). 138
 Error whitespace ParenPad ')' is preceded with whitespace. 162
 Error sizes LineLength Line is longer than 100 characters (found 122). 167
 Error sizes LineLength Line is longer than 100 characters (found 103). 174
 Error sizes LineLength Line is longer than 100 characters (found 127). 178
 Error sizes LineLength Line is longer than 100 characters (found 108). 180
 Error whitespace ParenPad ')' is preceded with whitespace. 182
 Error sizes LineLength Line is longer than 100 characters (found 131). 187
 Error sizes LineLength Line is longer than 100 characters (found 136). 194
 Error whitespace ParenPad ')' is preceded with whitespace. 198
 Error sizes LineLength Line is longer than 100 characters (found 142). 203
 Error sizes LineLength Line is longer than 100 characters (found 158). 210
 Error whitespace ParenPad ')' is preceded with whitespace. 214
 Error sizes LineLength Line is longer than 100 characters (found 164). 219
 Error whitespace ParenPad ')' is preceded with whitespace. 240
 Error sizes LineLength Line is longer than 100 characters (found 137). 245
 Error sizes LineLength Line is longer than 100 characters (found 158). 247
 Error sizes LineLength Line is longer than 100 characters (found 134). 249
 Error sizes LineLength Line is longer than 100 characters (found 102). 256
 Error sizes LineLength Line is longer than 100 characters (found 102). 260
 Error whitespace ParenPad ')' is preceded with whitespace. 264
 Error sizes LineLength Line is longer than 100 characters (found 412). 267
 Error whitespace ParenPad ')' is preceded with whitespace. 269
 Error sizes LineLength Line is longer than 100 characters (found 124). 274
 Error sizes LineLength Line is longer than 100 characters (found 132). 278
 Error sizes LineLength Line is longer than 100 characters (found 123). 282
 Error sizes LineLength Line is longer than 100 characters (found 123). 286
 Error sizes LineLength Line is longer than 100 characters (found 107). 303
 Error whitespace ParenPad ')' is preceded with whitespace. 307
 Error sizes LineLength Line is longer than 100 characters (found 217). 316
 Error sizes LineLength Line is longer than 100 characters (found 165). 318
 Error sizes LineLength Line is longer than 100 characters (found 152). 321
 Error sizes LineLength Line is longer than 100 characters (found 162). 323
 Error sizes LineLength Line is longer than 100 characters (found 188). 326
 Error sizes LineLength Line is longer than 100 characters (found 165). 328
 Error sizes LineLength Line is longer than 100 characters (found 200). 344
 Error sizes LineLength Line is longer than 100 characters (found 108). 352
 Error whitespace ParenPad ')' is preceded with whitespace. 356
 Error sizes LineLength Line is longer than 100 characters (found 231). 365
 Error sizes LineLength Line is longer than 100 characters (found 135). 367
 Error sizes LineLength Line is longer than 100 characters (found 213). 369
 Error sizes LineLength Line is longer than 100 characters (found 136). 371
 Error sizes LineLength Line is longer than 100 characters (found 166). 373
 Error sizes LineLength Line is longer than 100 characters (found 139). 375
 Error sizes LineLength Line is longer than 100 characters (found 166). 377
 Error sizes LineLength Line is longer than 100 characters (found 138). 379
 Error sizes LineLength Line is longer than 100 characters (found 167). 381
 Error sizes LineLength Line is longer than 100 characters (found 132). 383
 Error sizes LineLength Line is longer than 100 characters (found 214). 385
 Error sizes LineLength Line is longer than 100 characters (found 139). 387
 Error sizes LineLength Line is longer than 100 characters (found 177). 389
 Error sizes LineLength Line is longer than 100 characters (found 134). 391
 Error sizes LineLength Line is longer than 100 characters (found 123). 393
 Error sizes LineLength Line is longer than 100 characters (found 151). 401
 Error sizes LineLength Line is longer than 100 characters (found 103). 428
 Error sizes LineLength Line is longer than 100 characters (found 104). 432
 Error sizes LineLength Line is longer than 100 characters (found 103). 439
 Error sizes LineLength Line is longer than 100 characters (found 151). 451
 Error sizes LineLength Line is longer than 100 characters (found 147). 453
 Error sizes LineLength Line is longer than 100 characters (found 152). 455
 Error sizes LineLength Line is longer than 100 characters (found 113). 457
 Error whitespace ParenPad ')' is preceded with whitespace. 459
 Error sizes LineLength Line is longer than 100 characters (found 178). 464
 Error sizes LineLength Line is longer than 100 characters (found 110). 466
 Error sizes LineLength Line is longer than 100 characters (found 147). 480
 Error sizes LineLength Line is longer than 100 characters (found 152). 482
 Error sizes LineLength Line is longer than 100 characters (found 154). 484
 Error sizes LineLength Line is longer than 100 characters (found 181). 486
 Error sizes LineLength Line is longer than 100 characters (found 148). 488
 Error sizes LineLength Line is longer than 100 characters (found 186). 490
 Error sizes LineLength Line is longer than 100 characters (found 148). 492
 Error sizes LineLength Line is longer than 100 characters (found 191). 494
 Error sizes LineLength Line is longer than 100 characters (found 155). 496
 Error sizes LineLength Line is longer than 100 characters (found 101). 498
 Error sizes LineLength Line is longer than 100 characters (found 106). 500

org/apache/hadoop/hbase/tmpl/regionserver/BlockCacheViewTmpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 158). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.BlockCacheUtil.CachedBlocksByFile. 11
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.BlockCacheUtil. 13
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.CachedBlock. 15
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.BlockCache. 19
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats. 21
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketCache. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator. 25
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket. 27
 Error imports UnusedImports Unused import - org.apache.hadoop.util.StringUtils. 29
 Error sizes LineLength Line is longer than 100 characters (found 111). 124
 Error sizes LineLength Line is longer than 100 characters (found 133). 145
 Error sizes LineLength Line is longer than 100 characters (found 147). 157
 Error sizes LineLength Line is longer than 100 characters (found 154). 163

org/apache/hadoop/hbase/tmpl/regionserver/BlockCacheViewTmplImpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 158). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats. 21
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketCache. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator. 25
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket. 27
 Error imports UnusedImports Unused import - org.apache.hadoop.util.StringUtils. 29
 Error sizes LineLength Line is longer than 100 characters (found 199). 40
 Error sizes LineLength Line is longer than 100 characters (found 158). 44
 Error whitespace ParenPad ')' is preceded with whitespace. 76
 Error sizes LineLength Line is longer than 100 characters (found 125). 90
 Error sizes LineLength Line is longer than 100 characters (found 128). 94
 Error sizes LineLength Line is longer than 100 characters (found 110). 108
 Error sizes LineLength Line is longer than 100 characters (found 103). 114
 Error whitespace ParenPad ')' is preceded with whitespace. 114
 Error sizes LineLength Line is longer than 100 characters (found 147). 117

org/apache/hadoop/hbase/tmpl/regionserver/RSStatusTmpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 152). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HRegionInfo. 11
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ServerName. 13
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseConfiguration. 15
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.ProtobufUtil. 17
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo. 19
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.zookeeper.MasterAddressTracker. 21
 Error design VisibilityModifier Variable 'bcn' must be private and have accessor methods. 151
 Error design VisibilityModifier Variable 'filter' must be private and have accessor methods. 158
 Error design VisibilityModifier Variable 'bcv' must be private and have accessor methods. 165
 Error design VisibilityModifier Variable 'format' must be private and have accessor methods. 172
 Error sizes LineLength Line is longer than 100 characters (found 111). 181

org/apache/hadoop/hbase/tmpl/regionserver/RSStatusTmplImpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 152). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error sizes LineLength Line is longer than 100 characters (found 187). 33
 Error sizes LineLength Line is longer than 100 characters (found 146). 53
 Error sizes MethodLength Method length is 186 lines (max allowed is 150). 63
 Error whitespace ParenPad ')' is preceded with whitespace. 67
 Error sizes LineLength Line is longer than 100 characters (found 178). 73
 Error sizes LineLength Line is longer than 100 characters (found 124). 74
 Error whitespace ParenPad ')' is preceded with whitespace. 82
 Error sizes LineLength Line is longer than 100 characters (found 160). 88
 Error whitespace ParenPad ')' is preceded with whitespace. 89
 Error sizes LineLength Line is longer than 100 characters (found 208). 111
 Error sizes LineLength Line is longer than 100 characters (found 122). 113
 Error sizes LineLength Line is longer than 100 characters (found 271). 123
 Error sizes LineLength Line is longer than 100 characters (found 108). 125
 Error sizes LineLength Line is longer than 100 characters (found 144). 127
 Error sizes LineLength Line is longer than 100 characters (found 174). 130
 Error sizes LineLength Line is longer than 100 characters (found 178). 131
 Error sizes LineLength Line is longer than 100 characters (found 158). 137
 Error whitespace ParenPad ')' is preceded with whitespace. 138
 Error sizes LineLength Line is longer than 100 characters (found 169). 145
 Error sizes LineLength Line is longer than 100 characters (found 114). 146
 Error whitespace ParenPad ')' is preceded with whitespace. 146
 Error sizes LineLength Line is longer than 100 characters (found 169). 152
 Error sizes LineLength Line is longer than 100 characters (found 358). 156
 Error sizes LineLength Line is longer than 100 characters (found 151). 158
 Error sizes LineLength Line is longer than 100 characters (found 152). 162
 Error sizes LineLength Line is longer than 100 characters (found 164). 164
 Error sizes LineLength Line is longer than 100 characters (found 148). 166
 Error sizes LineLength Line is longer than 100 characters (found 148). 170
 Error sizes LineLength Line is longer than 100 characters (found 188). 172
 Error sizes LineLength Line is longer than 100 characters (found 155). 174
 Error sizes LineLength Line is longer than 100 characters (found 163). 176
 Error sizes LineLength Line is longer than 100 characters (found 145). 178
 Error sizes LineLength Line is longer than 100 characters (found 146). 182
 Error sizes LineLength Line is longer than 100 characters (found 166). 184
 Error sizes LineLength Line is longer than 100 characters (found 142). 186
 Error sizes LineLength Line is longer than 100 characters (found 142). 190
 Error sizes LineLength Line is longer than 100 characters (found 190). 192
 Error sizes LineLength Line is longer than 100 characters (found 149). 194
 Error sizes LineLength Line is longer than 100 characters (found 174). 196
 Error sizes LineLength Line is longer than 100 characters (found 139). 198
 Error sizes LineLength Line is longer than 100 characters (found 140). 202
 Error sizes LineLength Line is longer than 100 characters (found 186). 204
 Error sizes LineLength Line is longer than 100 characters (found 141). 206
 Error sizes LineLength Line is longer than 100 characters (found 182). 208
 Error sizes LineLength Line is longer than 100 characters (found 137). 210
 Error sizes LineLength Line is longer than 100 characters (found 174). 212
 Error sizes LineLength Line is longer than 100 characters (found 167). 214
 Error sizes LineLength Line is longer than 100 characters (found 187). 216
 Error sizes LineLength Line is longer than 100 characters (found 135). 218
 Error sizes LineLength Line is longer than 100 characters (found 203). 220
 Error whitespace ParenPad ')' is preceded with whitespace. 222
 Error sizes LineLength Line is longer than 100 characters (found 103). 240
 Error sizes LineLength Line is longer than 100 characters (found 104). 244
 Error sizes LineLength Line is longer than 100 characters (found 403). 249

org/apache/hadoop/hbase/tmpl/regionserver/RegionListTmpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 154). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.Bytes. 11
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.Region. 15
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ServerName. 17
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseConfiguration. 19
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.ProtobufUtil. 21
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad. 25
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.RegionReplicaUtil. 27
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper. 29
 Error imports UnusedImports Unused import - org.apache.hadoop.util.StringUtils.TraditionalBinaryPrefix. 31
 Error sizes LineLength Line is longer than 100 characters (found 111). 102
 Error sizes LineLength Line is longer than 100 characters (found 113). 123
 Error sizes LineLength Line is longer than 100 characters (found 127). 135
 Error sizes LineLength Line is longer than 100 characters (found 134). 141

org/apache/hadoop/hbase/tmpl/regionserver/RegionListTmplImpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 154). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.Region. 15
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ServerName. 17
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseConfiguration. 19
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.ProtobufUtil. 21
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.client.RegionReplicaUtil. 27
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.MetricsRegionWrapper. 29
 Error sizes LineLength Line is longer than 100 characters (found 191). 40
 Error sizes LineLength Line is longer than 100 characters (found 150). 44
 Error whitespace ParenPad ')' is preceded with whitespace. 55
 Error sizes LineLength Line is longer than 100 characters (found 134). 71
 Error sizes LineLength Line is longer than 100 characters (found 132). 78
 Error sizes LineLength Line is longer than 100 characters (found 135). 85
 Error sizes LineLength Line is longer than 100 characters (found 134). 92
 Error sizes LineLength Line is longer than 100 characters (found 115). 113
 Error sizes LineLength Line is longer than 100 characters (found 232). 117
 Error whitespace ParenPad ')' is preceded with whitespace. 119
 Error sizes LineLength Line is longer than 100 characters (found 118). 124
 Error sizes LineLength Line is longer than 100 characters (found 125). 128
 Error sizes LineLength Line is longer than 100 characters (found 137). 132
 Error sizes LineLength Line is longer than 100 characters (found 135). 136
 Error sizes LineLength Line is longer than 100 characters (found 116). 140
 Error sizes LineLength Line is longer than 100 characters (found 117). 150
 Error sizes LineLength Line is longer than 100 characters (found 399). 154
 Error whitespace ParenPad ')' is preceded with whitespace. 156
 Error sizes LineLength Line is longer than 100 characters (found 118). 167
 Error sizes LineLength Line is longer than 100 characters (found 125). 171
 Error whitespace ParenPad ')' is preceded with whitespace. 175
 Error sizes LineLength Line is longer than 100 characters (found 118). 180
 Error sizes LineLength Line is longer than 100 characters (found 122). 184
 Error sizes LineLength Line is longer than 100 characters (found 155). 188
 Error sizes LineLength Line is longer than 100 characters (found 147). 193
 Error sizes LineLength Line is longer than 100 characters (found 154). 198
 Error sizes LineLength Line is longer than 100 characters (found 154). 203
 Error sizes LineLength Line is longer than 100 characters (found 124). 208
 Error sizes LineLength Line is longer than 100 characters (found 119). 221
 Error sizes LineLength Line is longer than 100 characters (found 221). 225
 Error whitespace ParenPad ')' is preceded with whitespace. 227
 Error sizes LineLength Line is longer than 100 characters (found 118). 238
 Error sizes LineLength Line is longer than 100 characters (found 125). 242
 Error whitespace ParenPad ')' is preceded with whitespace. 246
 Error sizes LineLength Line is longer than 100 characters (found 129). 251
 Error sizes LineLength Line is longer than 100 characters (found 130). 255
 Error sizes LineLength Line is longer than 100 characters (found 120). 268
 Error sizes LineLength Line is longer than 100 characters (found 174). 272
 Error whitespace ParenPad ')' is preceded with whitespace. 274
 Error sizes LineLength Line is longer than 100 characters (found 118). 285
 Error sizes LineLength Line is longer than 100 characters (found 125). 289
 Error whitespace ParenPad ')' is preceded with whitespace. 293
 Error sizes LineLength Line is longer than 100 characters (found 122). 298
 Error sizes LineLength Line is longer than 100 characters (found 102). 299
 Error sizes LineLength Line is longer than 100 characters (found 119). 312
 Error sizes LineLength Line is longer than 100 characters (found 263). 316
 Error whitespace ParenPad ')' is preceded with whitespace. 318
 Error sizes LineLength Line is longer than 100 characters (found 118). 334
 Error sizes LineLength Line is longer than 100 characters (found 125). 338
 Error whitespace ParenPad ')' is preceded with whitespace. 342
 Error sizes LineLength Line is longer than 100 characters (found 130). 347
 Error sizes LineLength Line is longer than 100 characters (found 131). 351
 Error sizes LineLength Line is longer than 100 characters (found 113). 355

org/apache/hadoop/hbase/tmpl/regionserver/ServerMetricsTmpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 157). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.HRegionServer. 9
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.Bytes. 15
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HRegionInfo. 17
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ServerName. 19
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseConfiguration. 21
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.ProtobufUtil. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo. 25
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad. 27
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.DirectMemoryUtils. 29
 Error imports UnusedImports Unused import - org.apache.hadoop.util.StringUtils.TraditionalBinaryPrefix. 31
 Error imports UnusedImports Unused import - java.lang.management.ManagementFactory. 33
 Error sizes LineLength Line is longer than 100 characters (found 111). 104
 Error sizes LineLength Line is longer than 100 characters (found 125). 125
 Error sizes LineLength Line is longer than 100 characters (found 139). 137
 Error sizes LineLength Line is longer than 100 characters (found 146). 143

org/apache/hadoop/hbase/tmpl/regionserver/ServerMetricsTmplImpl.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 157). 2
 Error imports AvoidStarImport Using the '.*' form of import should be avoided - java.util.*. 7
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.regionserver.HRegionServer. 9
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.Bytes. 15
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HRegionInfo. 17
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.ServerName. 19
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HBaseConfiguration. 21
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.ProtobufUtil. 23
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ServerInfo. 25
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad. 27
 Error sizes LineLength Line is longer than 100 characters (found 197). 42
 Error sizes LineLength Line is longer than 100 characters (found 156). 46
 Error whitespace ParenPad ')' is preceded with whitespace. 61
 Error sizes LineLength Line is longer than 100 characters (found 113). 64
 Error whitespace ParenPad ')' is preceded with whitespace. 68
 Error sizes LineLength Line is longer than 100 characters (found 114). 71
 Error whitespace ParenPad ')' is preceded with whitespace. 75
 Error sizes LineLength Line is longer than 100 characters (found 110). 78
 Error whitespace ParenPad ')' is preceded with whitespace. 82
 Error sizes LineLength Line is longer than 100 characters (found 112). 85
 Error whitespace ParenPad ')' is preceded with whitespace. 89
 Error sizes LineLength Line is longer than 100 characters (found 112). 92
 Error sizes LineLength Line is longer than 100 characters (found 118). 104
 Error sizes LineLength Line is longer than 100 characters (found 254). 108
 Error sizes LineLength Line is longer than 100 characters (found 118). 110
 Error sizes LineLength Line is longer than 100 characters (found 122). 114
 Error sizes LineLength Line is longer than 100 characters (found 172). 118
 Error sizes LineLength Line is longer than 100 characters (found 174). 122
 Error sizes LineLength Line is longer than 100 characters (found 174). 126
 Error sizes LineLength Line is longer than 100 characters (found 120). 133
 Error sizes LineLength Line is longer than 100 characters (found 192). 137
 Error sizes LineLength Line is longer than 100 characters (found 149). 139
 Error sizes LineLength Line is longer than 100 characters (found 126). 143
 Error sizes LineLength Line is longer than 100 characters (found 127). 147
 Error sizes LineLength Line is longer than 100 characters (found 119). 154
 Error sizes LineLength Line is longer than 100 characters (found 290). 158
 Error sizes LineLength Line is longer than 100 characters (found 118). 160
 Error sizes LineLength Line is longer than 100 characters (found 103). 161
 Error sizes LineLength Line is longer than 100 characters (found 118). 165
 Error sizes LineLength Line is longer than 100 characters (found 102). 166
 Error sizes LineLength Line is longer than 100 characters (found 183). 170
 Error sizes LineLength Line is longer than 100 characters (found 182). 174
 Error sizes LineLength Line is longer than 100 characters (found 166). 178
 Error sizes LineLength Line is longer than 100 characters (found 116). 185
 Error sizes LineLength Line is longer than 100 characters (found 188). 189
 Error sizes LineLength Line is longer than 100 characters (found 120). 191
 Error sizes LineLength Line is longer than 100 characters (found 165). 195
 Error sizes LineLength Line is longer than 100 characters (found 117). 202
 Error sizes LineLength Line is longer than 100 characters (found 306). 206
 Error sizes LineLength Line is longer than 100 characters (found 149). 208
 Error sizes LineLength Line is longer than 100 characters (found 125). 212
 Error sizes LineLength Line is longer than 100 characters (found 125). 216
 Error sizes LineLength Line is longer than 100 characters (found 141). 220
 Error sizes LineLength Line is longer than 100 characters (found 163). 231
 Error sizes LineLength Line is longer than 100 characters (found 334). 235
 Error sizes LineLength Line is longer than 100 characters (found 128). 237
 Error sizes LineLength Line is longer than 100 characters (found 123). 241
 Error sizes LineLength Line is longer than 100 characters (found 174). 245
 Error sizes LineLength Line is longer than 100 characters (found 134). 249
 Error sizes LineLength Line is longer than 100 characters (found 133). 253
 Error sizes LineLength Line is longer than 100 characters (found 137). 257

org/apache/hadoop/hbase/tool/Canary.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'connection' must be private and have accessor methods. 355
 Error design VisibilityModifier Variable 'admin' must be private and have accessor methods. 356
 Error design VisibilityModifier Variable 'targets' must be private and have accessor methods. 357
 Error design VisibilityModifier Variable 'useRegExp' must be private and have accessor methods. 358
 Error design VisibilityModifier Variable 'initialized' must be private and have accessor methods. 359
 Error design VisibilityModifier Variable 'done' must be private and have accessor methods. 361
 Error design VisibilityModifier Variable 'errorCode' must be private and have accessor methods. 362
 Error design VisibilityModifier Variable 'sink' must be private and have accessor methods. 363
 Error blocks EmptyBlock Must have at least one statement. 698
 Error blocks EmptyBlock Must have at least one statement. 714

org/apache/hadoop/hbase/trace/SpanReceiverHost.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'lock' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'host' must be private and have accessor methods. 48

org/apache/hadoop/hbase/types/CopyOnWriteArrayMap.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'index' must be private and have accessor methods. 707
 Error design VisibilityModifier Variable 'index' must be private and have accessor methods. 733
 Error design VisibilityModifier Variable 'index' must be private and have accessor methods. 760
 Error design VisibilityModifier Variable 'key' must be private and have accessor methods. 949
 Error design VisibilityModifier Variable 'value' must be private and have accessor methods. 950

org/apache/hadoop/hbase/types/FixedLengthWrapper.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'base' must be private and have accessor methods. 36
 Error design VisibilityModifier Variable 'length' must be private and have accessor methods. 37

org/apache/hadoop/hbase/types/OrderedBytesBase.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'order' must be private and have accessor methods. 34

org/apache/hadoop/hbase/types/PBType.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 22 - org.apache.hadoop.hbase.util.Order. 28
 Error imports RedundantImport Duplicate import to line 23 - org.apache.hadoop.hbase.util.PositionedByteRange. 29

org/apache/hadoop/hbase/types/RawBytes.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'order' must be private and have accessor methods. 44

org/apache/hadoop/hbase/types/RawString.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'order' must be private and have accessor methods. 41

org/apache/hadoop/hbase/types/Struct.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'fields' must be private and have accessor methods. 85
 Error design VisibilityModifier Variable 'isOrderPreserving' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'isSkippable' must be private and have accessor methods. 87

org/apache/hadoop/hbase/types/StructBuilder.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'fields' must be private and have accessor methods. 33

org/apache/hadoop/hbase/types/StructIterator.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'src' must be private and have accessor methods. 53
 Error design VisibilityModifier Variable 'idx' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'types' must be private and have accessor methods. 56

org/apache/hadoop/hbase/types/TerminatedWrapper.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'wrapped' must be private and have accessor methods. 37
 Error design VisibilityModifier Variable 'term' must be private and have accessor methods. 38

org/apache/hadoop/hbase/types/Union2.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'typeA' must be private and have accessor methods. 35
 Error design VisibilityModifier Variable 'typeB' must be private and have accessor methods. 36

org/apache/hadoop/hbase/types/Union3.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'typeC' must be private and have accessor methods. 36

org/apache/hadoop/hbase/types/Union4.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'typeD' must be private and have accessor methods. 35

org/apache/hadoop/hbase/util/AbstractByteRange.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'bytes' must be private and have accessor methods. 71
 Error design VisibilityModifier Variable 'offset' must be private and have accessor methods. 77
 Error design VisibilityModifier Variable 'length' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'hash' must be private and have accessor methods. 88

org/apache/hadoop/hbase/util/AbstractFileStatusFilter.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 104). 64

org/apache/hadoop/hbase/util/AbstractHBaseTool.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'cmdLineArgs' must be private and have accessor methods. 58
 Error misc ArrayTypeStyle Array brackets at illegal position. 192

org/apache/hadoop/hbase/util/AbstractPositionedByteRange.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'position' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'limit' must be private and have accessor methods. 49

org/apache/hadoop/hbase/util/Addressing.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 34

org/apache/hadoop/hbase/util/ArrayUtils.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 30

org/apache/hadoop/hbase/util/AtomicUtils.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 27

org/apache/hadoop/hbase/util/Base64.java

Severity Category Rule Message Line
 Error design FinalClass Class Base64 should be declared as final. 120
 Error coding InnerAssignment Inner assignments should be avoided. 950
 Error blocks EmptyBlock Must have at least one statement. 957
 Error coding InnerAssignment Inner assignments should be avoided. 1117
 Error coding InnerAssignment Inner assignments should be avoided. 1167
 Error whitespace ParenPad '(' is followed by whitespace. 1391

org/apache/hadoop/hbase/util/BoundedConcurrentLinkedQueue.java

Severity Category Rule Message Line
 Error coding InnerAssignment Inner assignments should be avoided. 110

org/apache/hadoop/hbase/util/ByteBloomFilter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'byteSize' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'hashCount' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'hashType' must be private and have accessor methods. 91
 Error design VisibilityModifier Variable 'hash' must be private and have accessor methods. 93
 Error design VisibilityModifier Variable 'keyCount' must be private and have accessor methods. 95
 Error design VisibilityModifier Variable 'maxKeys' must be private and have accessor methods. 97
 Error design VisibilityModifier Variable 'bloom' must be private and have accessor methods. 99
 Error whitespace ParenPad '(' is followed by whitespace. 510
 Error whitespace ParenPad ')' is preceded with whitespace. 510

org/apache/hadoop/hbase/util/ByteBufferArray.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 40
 Error misc ArrayTypeStyle Array brackets at illegal position. 41

org/apache/hadoop/hbase/util/ByteBufferUtils.java

Severity Category Rule Message Line
 Error misc UpperEll Should use uppercase 'L'. 193
 Error misc UpperEll Should use uppercase 'L'. 195
 Error misc UpperEll Should use uppercase 'L'. 196
 Error misc UpperEll Should use uppercase 'L'. 201
 Error misc UpperEll Should use uppercase 'L'. 207
 Error misc UpperEll Should use uppercase 'L'. 208
 Error misc UpperEll Should use uppercase 'L'. 213
 Error misc UpperEll Should use uppercase 'L'. 285
 Error misc UpperEll Should use uppercase 'L'. 298
 Error misc UpperEll Should use uppercase 'L'. 298
 Error sizes LineLength Line is longer than 100 characters (found 101). 497

org/apache/hadoop/hbase/util/ByteRangeUtils.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 34

org/apache/hadoop/hbase/util/ByteStringer.java

Severity Category Rule Message Line
 Error design FinalClass Class ByteStringer should be declared as final. 30

org/apache/hadoop/hbase/util/Bytes.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.lang.reflect.Field. 27
 Error imports UnusedImports Unused import - java.security.AccessController. 33
 Error imports UnusedImports Unused import - java.security.PrivilegedAction. 34
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 64
 Error misc UpperEll Should use uppercase 'L'. 125
 Error whitespace ParenPad ')' is preceded with whitespace. 458
 Error whitespace ParenPad ')' is preceded with whitespace. 463
 Error whitespace ParenPad '(' is followed by whitespace. 485
 Error whitespace ParenPad ')' is preceded with whitespace. 485

org/apache/hadoop/hbase/util/ChecksumFactory.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the java.lang package - java.lang.ClassNotFoundException. 23
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 35

org/apache/hadoop/hbase/util/ChecksumType.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'LOG' must be private and have accessor methods. 133

org/apache/hadoop/hbase/util/ClassLoaderBase.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'parent' must be private and have accessor methods. 48

org/apache/hadoop/hbase/util/ClassSize.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 38
 Error whitespace ParenPad '(' is followed by whitespace. 302

org/apache/hadoop/hbase/util/Classes.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 28

org/apache/hadoop/hbase/util/CollectionBackedScanner.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 39

org/apache/hadoop/hbase/util/CollectionUtils.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 31

org/apache/hadoop/hbase/util/CompoundBloomFilterBase.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'numChunks' must be private and have accessor methods. 35
 Error design VisibilityModifier Variable 'errorRate' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'totalKeyCount' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'totalByteSize' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'totalMaxKeys' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'hashType' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'comparator' must be private and have accessor methods. 55

org/apache/hadoop/hbase/util/CompoundBloomFilterWriter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'chunkId' must be private and have accessor methods. 63
 Error design VisibilityModifier Variable 'firstKey' must be private and have accessor methods. 64
 Error design VisibilityModifier Variable 'chunk' must be private and have accessor methods. 65

org/apache/hadoop/hbase/util/CompressionTest.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 50
 Error design VisibilityModifier Variable 'path' must be private and have accessor methods. 106
 Error whitespace ParenPad '(' is followed by whitespace. 112

org/apache/hadoop/hbase/util/ConcatenatedLists.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'components' must be private and have accessor methods. 38
 Error design VisibilityModifier Variable 'size' must be private and have accessor methods. 39
 Error design VisibilityModifier Variable 'currentComponent' must be private and have accessor methods. 139
 Error design VisibilityModifier Variable 'indexWithinComponent' must be private and have accessor methods. 140
 Error design VisibilityModifier Variable 'nextWasCalled' must be private and have accessor methods. 141

org/apache/hadoop/hbase/util/ConfigUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 26

org/apache/hadoop/hbase/util/ConnectionCache.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'connection' must be private and have accessor methods. 191
 Error design VisibilityModifier Variable 'userName' must be private and have accessor methods. 192
 Error design VisibilityModifier Variable 'admin' must be private and have accessor methods. 194

org/apache/hadoop/hbase/util/CoprocessorClassLoader.java

Severity Category Rule Message Line
 Error design FinalClass Class CoprocessorClassLoader should be declared as final. 74

org/apache/hadoop/hbase/util/Counter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'p0' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'p1' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'p2' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'p3' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'p4' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'p5' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'p6' must be private and have accessor methods. 41
 Error design VisibilityModifier Variable 'value' must be private and have accessor methods. 42
 Error design VisibilityModifier Variable 'q0' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'q1' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'q2' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'q3' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'q4' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'q5' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'q6' must be private and have accessor methods. 44
 Error design VisibilityModifier Variable 'cells' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'demoted' must be private and have accessor methods. 70

org/apache/hadoop/hbase/util/DNS.java

Severity Category Rule Message Line
 Error design FinalClass Class DNS should be declared as final. 27

org/apache/hadoop/hbase/util/DirectMemoryUtils.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 44

org/apache/hadoop/hbase/util/EncryptionTest.java

Severity Category Rule Message Line
 Error design FinalClass Class EncryptionTest should be declared as final. 38

org/apache/hadoop/hbase/util/EnvironmentEdgeManager.java

Severity Category Rule Message Line
 Error design FinalClass Class EnvironmentEdgeManager should be declared as final. 28

org/apache/hadoop/hbase/util/ExceptionUtil.java

Severity Category Rule Message Line
 Error design FinalClass Class ExceptionUtil should be declared as final. 36

org/apache/hadoop/hbase/util/FSRegionScanner.java

Severity Category Rule Message Line
 Error imports RedundantImport Redundant import from the same package - org.apache.hadoop.hbase.util.FSUtils. 33

org/apache/hadoop/hbase/util/FSTableDescriptorMigrationToSubdir.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 38

org/apache/hadoop/hbase/util/FSTableDescriptors.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'cachehits' must be private and have accessor methods. 80
 Error design VisibilityModifier Variable 'invocations' must be private and have accessor methods. 81
 Error blocks EmptyBlock Must have at least one statement. 178
 Error sizes LineLength Line is longer than 100 characters (found 130). 231

org/apache/hadoop/hbase/util/FSUtils.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hdfs.protocol.FSConstants. 84
 Error sizes LineLength Line is longer than 100 characters (found 102). 351
 Error sizes LineLength Line is longer than 100 characters (found 102). 649
 Error blocks EmptyBlock Must have at least one statement. 775
 Error blocks EmptyBlock Must have at least one statement. 926
 Error sizes LineLength Line is longer than 100 characters (found 108). 972
 Error sizes LineLength Line is longer than 100 characters (found 104). 973
 Error sizes LineLength Line is longer than 100 characters (found 114). 1027
 Error sizes LineLength Line is longer than 100 characters (found 126). 1052
 Error sizes LineLength Line is longer than 100 characters (found 105). 1053
 Error blocks EmptyBlock Must have at least one statement. 1395
 Error sizes LineLength Line is longer than 100 characters (found 105). 1449
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 1479
 Error sizes LineLength Line is longer than 100 characters (found 103). 1509
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 1528
 Error sizes LineLength Line is longer than 100 characters (found 104). 1562
 Error sizes LineLength Line is longer than 100 characters (found 112). 1573
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 1590
 Error sizes LineLength Line is longer than 100 characters (found 101). 1694
 Error sizes LineLength Line is longer than 100 characters (found 102). 1708
 Error sizes LineLength Line is longer than 100 characters (found 110). 1721
 Error sizes LineLength Line is longer than 100 characters (found 101). 1743
 Error whitespace ParenPad '(' is followed by whitespace. 1769
 Error sizes LineLength Line is longer than 100 characters (found 101). 2180
 Error sizes LineLength Line is longer than 100 characters (found 110). 2182

org/apache/hadoop/hbase/util/FSVisitor.java

Severity Category Rule Message Line
 Error whitespace MethodParamPad '(' is preceded with whitespace. 52
 Error whitespace MethodParamPad '(' is preceded with whitespace. 57
 Error sizes LineLength Line is longer than 100 characters (found 113). 98
 Error sizes LineLength Line is longer than 100 characters (found 115). 121

org/apache/hadoop/hbase/util/GetJavaProperty.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 24
 Error misc ArrayTypeStyle Array brackets at illegal position. 25

org/apache/hadoop/hbase/util/HBaseConfTool.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 30
 Error misc ArrayTypeStyle Array brackets at illegal position. 32

org/apache/hadoop/hbase/util/HBaseFsck.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 70 - org.apache.hadoop.hbase.classification.InterfaceAudience. 98
 Error imports RedundantImport Duplicate import to line 71 - org.apache.hadoop.hbase.classification.InterfaceStability. 99
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.zookeeper.MetaTableLocator. 138
 Error design VisibilityModifier Variable 'executor' must be private and have accessor methods. 229
 Error sizes LineLength Line is longer than 100 characters (found 120). 266
 Error design VisibilityModifier Variable 'fixes' must be private and have accessor methods. 280
 Error design VisibilityModifier Variable 'retryCounter' must be private and have accessor methods. 377
 Error whitespace MethodParamPad '(' is preceded with whitespace. 795
 Error design VisibilityModifier Variable 'regionName' must be private and have accessor methods. 821
 Error design VisibilityModifier Variable 'metaFirstKey' must be private and have accessor methods. 822
 Error design VisibilityModifier Variable 'metaLastKey' must be private and have accessor methods. 823
 Error design VisibilityModifier Variable 'storesFirstKey' must be private and have accessor methods. 824
 Error design VisibilityModifier Variable 'storesLastKey' must be private and have accessor methods. 825
 Error whitespace MethodParamPad '(' is preceded with whitespace. 827
 Error whitespace ParenPad ')' is preceded with whitespace. 995
 Error sizes LineLength Line is longer than 100 characters (found 118). 1152
 Error sizes LineLength Line is longer than 100 characters (found 113). 1153
 Error sizes LineLength Line is longer than 100 characters (found 104). 1161
 Error sizes LineLength Line is longer than 100 characters (found 113). 1162
 Error sizes LineLength Line is longer than 100 characters (found 101). 1164
 Error design VisibilityModifier Variable 'ioe' must be private and have accessor methods. 1259
 Error sizes LineLength Line is longer than 100 characters (found 105). 1405
 Error sizes LineLength Line is longer than 100 characters (found 105). 1435
 Error sizes LineLength Line is longer than 100 characters (found 123). 1438
 Error sizes LineLength Line is longer than 100 characters (found 102). 1449
 Error whitespace ParenPad ')' is preceded with whitespace. 1503
 Error sizes LineLength Line is longer than 100 characters (found 106). 1873
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 1936
 Error whitespace ParenPad ')' is preceded with whitespace. 2075
 Error whitespace ParenPad ')' is preceded with whitespace. 2095
 Error sizes MethodLength Method length is 220 lines (max allowed is 150). 2265
 Error whitespace MethodParamPad '(' is preceded with whitespace. 2494
 Error design VisibilityModifier Variable 'overlapgroup' must be private and have accessor methods. 2654
 Error design VisibilityModifier Variable 'tableName' must be private and have accessor methods. 2673
 Error design VisibilityModifier Variable 'deployedOn' must be private and have accessor methods. 2674
 Error design VisibilityModifier Variable 'backwards' must be private and have accessor methods. 2677
 Error design VisibilityModifier Variable 'sidelinedRegions' must be private and have accessor methods. 2680
 Error design VisibilityModifier Variable 'sc' must be private and have accessor methods. 2683
 Error design VisibilityModifier Variable 'htds' must be private and have accessor methods. 2686
 Error design VisibilityModifier Variable 'overlapGroups' must be private and have accessor methods. 2689
 Error design VisibilityModifier Variable 'errors' must be private and have accessor methods. 2769
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 2841
 Error design VisibilityModifier Variable 'fixOverlaps' must be private and have accessor methods. 2843
 Error sizes LineLength Line is longer than 100 characters (found 103). 2897
 Error sizes LineLength Line is longer than 100 characters (found 101). 2938
 Error whitespace ParenPad ')' is preceded with whitespace. 3005
 Error design VisibilityModifier Variable 'countRecord' must be private and have accessor methods. 3488
 Error design VisibilityModifier Variable 'comp' must be private and have accessor methods. 3491
 Error design VisibilityModifier Variable 'regionServer' must be private and have accessor methods. 3582
 Error design VisibilityModifier Variable 'modTime' must be private and have accessor methods. 3583
 Error design VisibilityModifier Variable 'splitA' must be private and have accessor methods. 3584
 Error design VisibilityModifier Variable 'splitB' must be private and have accessor methods. 3584
 Error design VisibilityModifier Variable 'hri' must be private and have accessor methods. 3633
 Error design VisibilityModifier Variable 'hdfsRegionDir' must be private and have accessor methods. 3634
 Error design VisibilityModifier Variable 'hdfsRegionDirModTime' must be private and have accessor methods. 3635
 Error design VisibilityModifier Variable 'hdfsRegioninfoFilePresent' must be private and have accessor methods. 3636
 Error design VisibilityModifier Variable 'hdfsOnlyEdits' must be private and have accessor methods. 3637
 Error design VisibilityModifier Variable 'hri' must be private and have accessor methods. 3644
 Error design VisibilityModifier Variable 'hsa' must be private and have accessor methods. 3645
 Error whitespace ParenPad '(' is followed by whitespace. 3693
 Error whitespace ParenPad '(' is followed by whitespace. 3694
 Error whitespace ParenPad '(' is followed by whitespace. 3695
 Error sizes LineLength Line is longer than 100 characters (found 137). 3915
 Error sizes LineLength Line is longer than 100 characters (found 110). 3922
 Error design VisibilityModifier Variable 'errorCount' must be private and have accessor methods. 3953
 Error design VisibilityModifier Variable 'errorTables' must be private and have accessor methods. 3958
 Error sizes LineLength Line is longer than 100 characters (found 101). 4125
 Error coding EmptyStatement Empty statement. 4242
 Error sizes LineLength Line is longer than 100 characters (found 115). 4547
 Error sizes LineLength Line is longer than 100 characters (found 108). 4582
 Error sizes LineLength Line is longer than 100 characters (found 107). 4585
 Error sizes LineLength Line is longer than 100 characters (found 106). 4587
 Error sizes LineLength Line is longer than 100 characters (found 116). 4589
 Error sizes LineLength Line is longer than 100 characters (found 113). 4592
 Error sizes LineLength Line is longer than 100 characters (found 145). 4595
 Error sizes LineLength Line is longer than 100 characters (found 104). 4596
 Error sizes LineLength Line is longer than 100 characters (found 179). 4597
 Error sizes LineLength Line is longer than 100 characters (found 107). 4607
 Error sizes LineLength Line is longer than 100 characters (found 104). 4608
 Error sizes LineLength Line is longer than 100 characters (found 128). 4620
 Error sizes LineLength Line is longer than 100 characters (found 111). 4624
 Error sizes MethodLength Method length is 222 lines (max allowed is 150). 4664

org/apache/hadoop/hbase/util/HBaseFsckRepair.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 21 - java.io.IOException. 50
 Error imports RedundantImport Duplicate import to line 22 - java.util.Collection. 51
 Error imports RedundantImport Duplicate import to line 23 - java.util.List. 52
 Error imports RedundantImport Duplicate import to line 24 - java.util.Map. 53
 Error imports RedundantImport Duplicate import to line 25 - java.util.Random. 54
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 60

org/apache/hadoop/hbase/util/HFileArchiveUtil.java

Severity Category Rule Message Line
 Error design FinalClass Class HFileArchiveUtil should be declared as final. 33

org/apache/hadoop/hbase/util/HFileV1Detector.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 170
 Error misc ArrayTypeStyle Array brackets at illegal position. 415

org/apache/hadoop/hbase/util/HMerge.java

Severity Category Rule Message Line
 Error design FinalClass Class HMerge should be declared as final. 57
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 141
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 142
 Error design VisibilityModifier Variable 'rootDir' must be private and have accessor methods. 143
 Error design VisibilityModifier Variable 'htd' must be private and have accessor methods. 144
 Error design VisibilityModifier Variable 'walFactory' must be private and have accessor methods. 145

org/apache/hadoop/hbase/util/HttpServerUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 28

org/apache/hadoop/hbase/util/IdLock.java

Severity Category Rule Message Line
 Error design FinalClass Class Entry should be declared as final. 46

org/apache/hadoop/hbase/util/IterableUtils.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 30

org/apache/hadoop/hbase/util/JVM.java

Severity Category Rule Message Line
 Error whitespace MethodParamPad '(' is preceded with whitespace. 59
 Error whitespace MethodParamPad '(' is preceded with whitespace. 107
 Error whitespace MethodParamPad '(' is preceded with whitespace. 139
 Error coding InnerAssignment Inner assignments should be avoided. 156
 Error whitespace MethodParamPad '(' is preceded with whitespace. 245
 Error coding InnerAssignment Inner assignments should be avoided. 255

org/apache/hadoop/hbase/util/JVMClusterUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 38
 Error sizes LineLength Line is longer than 100 characters (found 102). 199

org/apache/hadoop/hbase/util/JenkinsHash.java

Severity Category Rule Message Line
 Error sizes MethodLength Method length is 158 lines (max allowed is 150). 81
 Error coding InnerAssignment Inner assignments should be avoided. 86
 Error coding InnerAssignment Inner assignments should be avoided. 86
 Error coding MissingSwitchDefault switch without "default" clause. 165

org/apache/hadoop/hbase/util/JvmPauseMonitor.java

Severity Category Rule Message Line
 Error design FinalClass Class GcTimes should be declared as final. 122

org/apache/hadoop/hbase/util/MBeanUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 30
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 32
 Error blocks EmptyBlock Must have at least one statement. 51
 Error whitespace ParenPad ')' is preceded with whitespace. 65
 Error blocks EmptyBlock Must have at least one statement. 65
 Error sizes LineLength Line is longer than 100 characters (found 105). 73

org/apache/hadoop/hbase/util/MD5Hash.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 35

org/apache/hadoop/hbase/util/ManualEnvironmentEdge.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 109). 24
 Error design VisibilityModifier Variable 'value' must be private and have accessor methods. 31

org/apache/hadoop/hbase/util/MapreduceDependencyClasspathTool.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 107). 53
 Error sizes LineLength Line is longer than 100 characters (found 106). 54

org/apache/hadoop/hbase/util/Merge.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.wal.WAL. 44
 Error blocks EmptyBlock Must have at least one statement. 101
 Error blocks EmptyBlock Must have at least one statement. 103

org/apache/hadoop/hbase/util/Methods.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 31

org/apache/hadoop/hbase/util/MurmurHash3.java

Severity Category Rule Message Line
 Error coding MissingSwitchDefault switch without "default" clause. 66

org/apache/hadoop/hbase/util/OrderedBytes.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 269
 Error coding InnerAssignment Inner assignments should be avoided. 348
 Error whitespace ParenPad '(' is followed by whitespace. 583
 Error whitespace ParenPad '(' is followed by whitespace. 584
 Error coding EmptyStatement Empty statement. 607
 Error coding EmptyStatement Empty statement. 987
 Error coding EmptyStatement Empty statement. 1103
 Error coding EmptyStatement Empty statement. 1737

org/apache/hadoop/hbase/util/Pair.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'first' must be private and have accessor methods. 37
 Error design VisibilityModifier Variable 'second' must be private and have accessor methods. 38

org/apache/hadoop/hbase/util/PoolMap.java

Severity Category Rule Message Line
 Error coding InnerAssignment Inner assignments should be avoided. 80
 Error coding MissingSwitchDefault switch without "default" clause. 271
 Error sizes LineLength Line is longer than 100 characters (found 125). 391
 Error coding InnerAssignment Inner assignments should be avoided. 402

org/apache/hadoop/hbase/util/PrettyPrinter.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 25
 Error whitespace ParenPad ')' is preceded with whitespace. 87

org/apache/hadoop/hbase/util/ProtoUtil.java

Severity Category Rule Message Line
 Error coding InnerAssignment Inner assignments should be avoided. 75
 Error coding InnerAssignment Inner assignments should be avoided. 79
 Error coding InnerAssignment Inner assignments should be avoided. 83
 Error coding InnerAssignment Inner assignments should be avoided. 87

org/apache/hadoop/hbase/util/ReflectionUtils.java

Severity Category Rule Message Line
 Error extension TreeWalker Got an exception - expecting EOF, found '}' 84

org/apache/hadoop/hbase/util/RegionSplitter.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 142
 Error sizes MethodLength Method length is 204 lines (max allowed is 150). 436
 Error coding InnerAssignment Inner assignments should be avoided. 736
 Error design VisibilityModifier Variable 'firstRow' must be private and have accessor methods. 891
 Error design VisibilityModifier Variable 'firstRowInt' must be private and have accessor methods. 892
 Error design VisibilityModifier Variable 'lastRow' must be private and have accessor methods. 893
 Error design VisibilityModifier Variable 'lastRowInt' must be private and have accessor methods. 894
 Error design VisibilityModifier Variable 'rowComparisonLength' must be private and have accessor methods. 895
 Error design VisibilityModifier Variable 'firstRowBytes' must be private and have accessor methods. 1042
 Error design VisibilityModifier Variable 'lastRowBytes' must be private and have accessor methods. 1043

org/apache/hadoop/hbase/util/RetryCounter.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 106). 126

org/apache/hadoop/hbase/util/ServerCommandLine.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 124

org/apache/hadoop/hbase/util/ShutdownHookManager.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'shutdownHookManagerClass' must be private and have accessor methods. 30

org/apache/hadoop/hbase/util/SimpleByteRange.java

Severity Category Rule Message Line
 Error coding EqualsHashCode Definition of 'equals()' without corresponding definition of 'hashCode()'. 129

org/apache/hadoop/hbase/util/SimpleMutableByteRange.java

Severity Category Rule Message Line
 Error coding EqualsHashCode Definition of 'equals()' without corresponding definition of 'hashCode()'. 227

org/apache/hadoop/hbase/util/Strings.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 26

org/apache/hadoop/hbase/util/Threads.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 41
 Error design VisibilityModifier Variable 'threadNumber' must be private and have accessor methods. 211
 Error design VisibilityModifier Variable 'group' must be private and have accessor methods. 213

org/apache/hadoop/hbase/util/UnsafeAccess.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.nio.ByteOrder. 23

org/apache/hadoop/hbase/util/VersionInfo.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 33
 Error misc ArrayTypeStyle Array brackets at illegal position. 132
 Error misc ArrayTypeStyle Array brackets at illegal position. 133
 Error blocks EmptyBlock Must have at least one statement. 139
 Error blocks EmptyBlock Must have at least one statement. 143

org/apache/hadoop/hbase/util/WeakObjectPool.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'key' must be private and have accessor methods. 56

org/apache/hadoop/hbase/util/Writables.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 36

org/apache/hadoop/hbase/util/ZKDataMigrator.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 250

org/apache/hadoop/hbase/util/byterange/ByteRangeSet.java

Severity Category Rule Message Line
 Error sizes LineLength Line is longer than 100 characters (found 103). 37
 Error sizes LineLength Line is longer than 100 characters (found 101). 38
 Error design VisibilityModifier Variable 'byteAppender' must be private and have accessor methods. 46
 Error design VisibilityModifier Variable 'numBytes' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'uniqueIndexByUniqueRange' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'uniqueRanges' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'numUniqueRanges' must be private and have accessor methods. 52
 Error design VisibilityModifier Variable 'uniqueRangeIndexByInsertionId' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'numInputs' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'sortedIndexByUniqueIndex' must be private and have accessor methods. 57
 Error design VisibilityModifier Variable 'sortedIndexByInsertionId' must be private and have accessor methods. 58
 Error design VisibilityModifier Variable 'sortedRanges' must be private and have accessor methods. 59

org/apache/hadoop/hbase/util/hbck/HFileCorruptionChecker.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 66
 Error design VisibilityModifier Variable 'cacheConf' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'executor' must be private and have accessor methods. 68
 Error design VisibilityModifier Variable 'corrupted' must be private and have accessor methods. 69
 Error design VisibilityModifier Variable 'failures' must be private and have accessor methods. 70
 Error design VisibilityModifier Variable 'quarantined' must be private and have accessor methods. 71
 Error design VisibilityModifier Variable 'missing' must be private and have accessor methods. 72
 Error design VisibilityModifier Variable 'corruptedMobFiles' must be private and have accessor methods. 73
 Error design VisibilityModifier Variable 'failureMobFiles' must be private and have accessor methods. 74
 Error design VisibilityModifier Variable 'missedMobFiles' must be private and have accessor methods. 75
 Error design VisibilityModifier Variable 'quarantinedMobFiles' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'inQuarantineMode' must be private and have accessor methods. 77
 Error design VisibilityModifier Variable 'hfilesChecked' must be private and have accessor methods. 78
 Error design VisibilityModifier Variable 'mobFilesChecked' must be private and have accessor methods. 79
 Error sizes LineLength Line is longer than 100 characters (found 101). 332
 Error design VisibilityModifier Variable 'regionDir' must be private and have accessor methods. 397

org/apache/hadoop/hbase/util/hbck/OfflineMetaRepair.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 46

org/apache/hadoop/hbase/util/hbck/TableIntegrityErrorHandlerImpl.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'ti' must be private and have accessor methods. 32

org/apache/hadoop/hbase/util/hbck/TableLockChecker.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.util.Bytes. 27
 Error design VisibilityModifier Variable 'expireTimeout' must be private and have accessor methods. 40

org/apache/hadoop/hbase/util/test/RedundantKVGenerator.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'DEFAULT_COMMON_PREFIX' must be private and have accessor methods. 45
 Error design VisibilityModifier Variable 'DEFAULT_NUMBER_OF_ROW_PREFIXES' must be private and have accessor methods. 46
 Error design VisibilityModifier Variable 'DEFAULT_AVERAGE_PREFIX_LENGTH' must be private and have accessor methods. 47
 Error design VisibilityModifier Variable 'DEFAULT_PREFIX_LENGTH_VARIANCE' must be private and have accessor methods. 48
 Error design VisibilityModifier Variable 'DEFAULT_AVERAGE_SUFFIX_LENGTH' must be private and have accessor methods. 49
 Error design VisibilityModifier Variable 'DEFAULT_SUFFIX_LENGTH_VARIANCE' must be private and have accessor methods. 50
 Error design VisibilityModifier Variable 'DEFAULT_NUMBER_OF_ROW' must be private and have accessor methods. 51
 Error design VisibilityModifier Variable 'DEFAULT_CHANCE_FOR_SAME_QUALIFIER' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'DEFAULT_CHANCE_FOR_SIMILIAR_QUALIFIER' must be private and have accessor methods. 55
 Error design VisibilityModifier Variable 'DEFAULT_AVERAGE_QUALIFIER_LENGTH' must be private and have accessor methods. 56
 Error design VisibilityModifier Variable 'DEFAULT_QUALIFIER_LENGTH_VARIANCE' must be private and have accessor methods. 57
 Error design VisibilityModifier Variable 'DEFAULT_COLUMN_FAMILY_LENGTH' must be private and have accessor methods. 59
 Error design VisibilityModifier Variable 'DEFAULT_VALUE_LENGTH' must be private and have accessor methods. 60
 Error design VisibilityModifier Variable 'DEFAULT_CHANCE_FOR_ZERO_VALUE' must be private and have accessor methods. 61
 Error design VisibilityModifier Variable 'DEFAULT_BASE_TIMESTAMP_DIVIDE' must be private and have accessor methods. 63
 Error design VisibilityModifier Variable 'DEFAULT_TIMESTAMP_DIFF_SIZE' must be private and have accessor methods. 64

org/apache/hadoop/hbase/util/vint/UFIntTool.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 50
 Error sizes LineLength Line is longer than 100 characters (found 104). 90

org/apache/hadoop/hbase/util/vint/UVIntTool.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 31

org/apache/hadoop/hbase/util/vint/UVLongTool.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 31

org/apache/hadoop/hbase/wal/DefaultWALProvider.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - java.io.Closeable. 21
 Error imports UnusedImports Unused import - java.io.DataInput. 22
 Error imports UnusedImports Unused import - java.io.DataOutput. 23
 Error design VisibilityModifier Variable 'log' must be private and have accessor methods. 78

org/apache/hadoop/hbase/wal/DisabledWALProvider.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'disabled' must be private and have accessor methods. 54
 Error design VisibilityModifier Variable 'listeners' must be private and have accessor methods. 84
 Error design VisibilityModifier Variable 'path' must be private and have accessor methods. 86
 Error design VisibilityModifier Variable 'coprocessorHost' must be private and have accessor methods. 87
 Error design VisibilityModifier Variable 'closed' must be private and have accessor methods. 88
 Error misc UpperEll Should use uppercase 'L'. 165
 Error misc UpperEll Should use uppercase 'L'. 177

org/apache/hadoop/hbase/wal/RegionGroupingProvider.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'clazz' must be private and have accessor methods. 76
 Error design VisibilityModifier Variable 'cached' must be private and have accessor methods. 121
 Error design VisibilityModifier Variable 'strategy' must be private and have accessor methods. 125

org/apache/hadoop/hbase/wal/WAL.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HConstants. 29

org/apache/hadoop/hbase/wal/WALFactory.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.HConstants. 38
 Error design VisibilityModifier Variable 'clazz' must be private and have accessor methods. 82
 Error design VisibilityModifier Variable 'factoryId' must be private and have accessor methods. 94
 Error design VisibilityModifier Variable 'provider' must be private and have accessor methods. 95
 Error design VisibilityModifier Variable 'metaProvider' must be private and have accessor methods. 99

org/apache/hadoop/hbase/wal/WALKey.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'code' must be private and have accessor methods. 91
 Error design VisibilityModifier Variable 'encodedRegionName' must be private and have accessor methods. 132
 Error design VisibilityModifier Variable 'tablename' must be private and have accessor methods. 135
 Error design VisibilityModifier Variable 'logSeqNum' must be private and have accessor methods. 138
 Error design VisibilityModifier Variable 'writeTime' must be private and have accessor methods. 144
 Error design VisibilityModifier Variable 'clusterIds' must be private and have accessor methods. 149
 Error design VisibilityModifier Variable 'compressionContext' must be private and have accessor methods. 159
 Error sizes LineLength Line is longer than 100 characters (found 133). 487
 Error sizes LineLength Line is longer than 100 characters (found 155). 489
 Error sizes LineLength Line is longer than 100 characters (found 144). 528

org/apache/hadoop/hbase/wal/WALProvider.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.classification.InterfaceStability. 26

org/apache/hadoop/hbase/wal/WALSplitter.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'rootDir' must be private and have accessor methods. 141
 Error design VisibilityModifier Variable 'fs' must be private and have accessor methods. 142
 Error design VisibilityModifier Variable 'conf' must be private and have accessor methods. 143
 Error design VisibilityModifier Variable 'controller' must be private and have accessor methods. 147
 Error design VisibilityModifier Variable 'outputSink' must be private and have accessor methods. 148
 Error design VisibilityModifier Variable 'entryBuffers' must be private and have accessor methods. 149
 Error design VisibilityModifier Variable 'sequenceIdChecker' must be private and have accessor methods. 159
 Error design VisibilityModifier Variable 'distributedLogReplay' must be private and have accessor methods. 161
 Error design VisibilityModifier Variable 'lastFlushedSequenceIds' must be private and have accessor methods. 164
 Error design VisibilityModifier Variable 'regionMaxSeqIdInStores' must be private and have accessor methods. 167
 Error design VisibilityModifier Variable 'failedServerName' must be private and have accessor methods. 171
 Error blocks EmptyBlock Must have at least one statement. 723
 Error design VisibilityModifier Variable 'thrown' must be private and have accessor methods. 859
 Error design VisibilityModifier Variable 'dataAvailable' must be private and have accessor methods. 863
 Error design VisibilityModifier Variable 'controller' must be private and have accessor methods. 891
 Error design VisibilityModifier Variable 'buffers' must be private and have accessor methods. 893
 Error design VisibilityModifier Variable 'currentlyWriting' must be private and have accessor methods. 899
 Error design VisibilityModifier Variable 'totalBuffered' must be private and have accessor methods. 901
 Error design VisibilityModifier Variable 'maxHeapUsage' must be private and have accessor methods. 902
 Error sizes LineLength Line is longer than 100 characters (found 101). 934
 Error design VisibilityModifier Variable 'heapInBuffer' must be private and have accessor methods. 1005
 Error design VisibilityModifier Variable 'entryBuffer' must be private and have accessor methods. 1006
 Error design VisibilityModifier Variable 'tableName' must be private and have accessor methods. 1007
 Error design VisibilityModifier Variable 'encodedRegionName' must be private and have accessor methods. 1008
 Error design VisibilityModifier Variable 'controller' must be private and have accessor methods. 1121
 Error design VisibilityModifier Variable 'entryBuffers' must be private and have accessor methods. 1122
 Error design VisibilityModifier Variable 'writers' must be private and have accessor methods. 1124
 Error design VisibilityModifier Variable 'regionMaximumEditLogSeqNum' must be private and have accessor methods. 1127
 Error design VisibilityModifier Variable 'writerThreads' must be private and have accessor methods. 1130
 Error design VisibilityModifier Variable 'blacklistedRegions' must be private and have accessor methods. 1133
 Error design VisibilityModifier Variable 'closeAndCleanCompleted' must be private and have accessor methods. 1136
 Error design VisibilityModifier Variable 'writersClosed' must be private and have accessor methods. 1138
 Error design VisibilityModifier Variable 'numThreads' must be private and have accessor methods. 1140
 Error design VisibilityModifier Variable 'reporter' must be private and have accessor methods. 1142
 Error design VisibilityModifier Variable 'skippedEdits' must be private and have accessor methods. 1144
 Error design VisibilityModifier Variable 'splits' must be private and have accessor methods. 1146
 Error misc ArrayTypeStyle Array brackets at illegal position. 1459
 Error design VisibilityModifier Variable 'editsWritten' must be private and have accessor methods. 1596
 Error design VisibilityModifier Variable 'editsSkipped' must be private and have accessor methods. 1598
 Error design VisibilityModifier Variable 'nanosSpent' must be private and have accessor methods. 1600
 Error design VisibilityModifier Variable 'p' must be private and have accessor methods. 1620
 Error design VisibilityModifier Variable 'w' must be private and have accessor methods. 1621
 Error misc UpperEll Should use uppercase 'L'. 1731
 Error misc UpperEll Should use uppercase 'L'. 1871
 Error design VisibilityModifier Variable 'sink' must be private and have accessor methods. 2169
 Error design VisibilityModifier Variable 'type' must be private and have accessor methods. 2201
 Error design VisibilityModifier Variable 'mutation' must be private and have accessor methods. 2202
 Error design VisibilityModifier Variable 'nonceGroup' must be private and have accessor methods. 2203
 Error design VisibilityModifier Variable 'nonce' must be private and have accessor methods. 2204

org/apache/hadoop/hbase/zookeeper/EmptyWatcher.java

Severity Category Rule Message Line
 Error design FinalClass Class EmptyWatcher should be declared as final. 27

org/apache/hadoop/hbase/zookeeper/HQuorumPeer.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 21 - org.apache.hadoop.hbase.classification.InterfaceAudience. 47
 Error imports RedundantImport Duplicate import to line 22 - org.apache.hadoop.hbase.classification.InterfaceStability. 48
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 58
 Error sizes LineLength Line is longer than 100 characters (found 103). 86

org/apache/hadoop/hbase/zookeeper/InstancePending.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'instance' must be private and have accessor methods. 39

org/apache/hadoop/hbase/zookeeper/MetaTableLocator.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 24 - org.apache.hadoop.hbase.classification.InterfaceAudience. 30
 Error imports RedundantImport Duplicate import to line 29 - org.apache.hadoop.hbase.ServerName. 37
 Error imports UnusedImports Unused import - javax.annotation.Nullable. 65
 Error blocks EmptyBlock Must have at least one statement. 288
 Error blocks EmptyBlock Must have at least one statement. 290
 Error blocks EmptyBlock Must have at least one statement. 292
 Error blocks EmptyBlock Must have at least one statement. 294
 Error blocks EmptyBlock Must have at least one statement. 393
 Error blocks EmptyBlock Must have at least one statement. 412
 Error blocks EmptyBlock Must have at least one statement. 414
 Error blocks EmptyBlock Must have at least one statement. 417
 Error whitespace MethodParamPad '(' should be on the previous line. 497
 Error blocks EmptyBlock Must have at least one statement. 544

org/apache/hadoop/hbase/zookeeper/RecoverableZooKeeper.java

Severity Category Rule Message Line
 Error blocks EmptyBlock Must have at least one statement. 128

org/apache/hadoop/hbase/zookeeper/RegionServerTracker.java

Severity Category Rule Message Line
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.Server. 30
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.master.AssignmentManager. 33
 Error imports UnusedImports Unused import - org.apache.hadoop.hbase.master.HMaster. 34

org/apache/hadoop/hbase/zookeeper/ZKAssign.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 94

org/apache/hadoop/hbase/zookeeper/ZKServerTool.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 34
 Error misc ArrayTypeStyle Array brackets at illegal position. 40

org/apache/hadoop/hbase/zookeeper/ZKSplitLog.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 43
 Error misc UpperEll Should use uppercase 'L'. 171
 Error misc UpperEll Should use uppercase 'L'. 175

org/apache/hadoop/hbase/zookeeper/ZKTableStateClientSideReader.java

Severity Category Rule Message Line
 Error design FinalClass Class ZKTableStateClientSideReader should be declared as final. 42

org/apache/hadoop/hbase/zookeeper/ZKTableStateManager.java

Severity Category Rule Message Line
 Error whitespace ParenPad ')' is preceded with whitespace. 126
 Error blocks EmptyBlock Must have at least one statement. 224

org/apache/hadoop/hbase/zookeeper/ZKUtil.java

Severity Category Rule Message Line
 Error design HideUtilityClassConstructor Utility classes should not have a public or default constructor. 91
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 749
 Error annotation MissingDeprecated Must include both @java.lang.Deprecated annotation and @deprecated Javadoc tag with description. 781
 Error blocks EmptyBlock Must have at least one statement. 1154
 Error blocks EmptyBlock Must have at least one statement. 1263
 Error design FinalClass Class CreateAndFailSilent should be declared as final. 1533
 Error design FinalClass Class DeleteNodeFailSilent should be declared as final. 1565
 Error design FinalClass Class SetData should be declared as final. 1587
 Error blocks EmptyBlock Must have at least one statement. 1846

org/apache/hadoop/hbase/zookeeper/ZooKeeperListener.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'watcher' must be private and have accessor methods. 39

org/apache/hadoop/hbase/zookeeper/ZooKeeperMainServer.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 69
 Error misc ArrayTypeStyle Array brackets at illegal position. 77
 Error misc ArrayTypeStyle Array brackets at illegal position. 89

org/apache/hadoop/hbase/zookeeper/ZooKeeperNodeTracker.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'node' must be private and have accessor methods. 40
 Error design VisibilityModifier Variable 'abortable' must be private and have accessor methods. 46
 Error whitespace ParenPad ')' is preceded with whitespace. 141

org/apache/hadoop/hbase/zookeeper/ZooKeeperWatcher.java

Severity Category Rule Message Line
 Error imports RedundantImport Duplicate import to line 32 - org.apache.hadoop.hbase.classification.InterfaceAudience. 39
 Error design VisibilityModifier Variable 'abortable' must be private and have accessor methods. 79
 Error design VisibilityModifier Variable 'saslLatch' must be private and have accessor methods. 89
 Error design VisibilityModifier Variable 'baseZNode' must be private and have accessor methods. 94
 Error design VisibilityModifier Variable 'rsZNode' must be private and have accessor methods. 98
 Error design VisibilityModifier Variable 'drainingZNode' must be private and have accessor methods. 100
 Error design VisibilityModifier Variable 'backupMasterAddressesZNode' must be private and have accessor methods. 104
 Error design VisibilityModifier Variable 'clusterStateZNode' must be private and have accessor methods. 106
 Error design VisibilityModifier Variable 'assignmentZNode' must be private and have accessor methods. 108
 Error design VisibilityModifier Variable 'tableZNode' must be private and have accessor methods. 110
 Error design VisibilityModifier Variable 'clusterIdZNode' must be private and have accessor methods. 112
 Error design VisibilityModifier Variable 'splitLogZNode' must be private and have accessor methods. 114
 Error design VisibilityModifier Variable 'balancerZNode' must be private and have accessor methods. 116
 Error design VisibilityModifier Variable 'tableLockZNode' must be private and have accessor methods. 122
 Error design VisibilityModifier Variable 'recoveringRegionsZNode' must be private and have accessor methods. 124
 Error design VisibilityModifier Variable 'namespaceZNode' must be private and have accessor methods. 126
 Error design VisibilityModifier Variable 'masterMaintZNode' must be private and have accessor methods. 128
 Error coding MissingSwitchDefault switch without "default" clause. 562

org/apache/hadoop/hbase/zookeeper/lock/ZKInterProcessLockBase.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'zkWatcher' must be private and have accessor methods. 62
 Error design VisibilityModifier Variable 'parentLockNode' must be private and have accessor methods. 63
 Error design VisibilityModifier Variable 'fullyQualifiedZNode' must be private and have accessor methods. 64
 Error design VisibilityModifier Variable 'childZNode' must be private and have accessor methods. 65
 Error design VisibilityModifier Variable 'metadata' must be private and have accessor methods. 66
 Error design VisibilityModifier Variable 'handler' must be private and have accessor methods. 67
 Error design VisibilityModifier Variable 'acquiredLock' must be private and have accessor methods. 70
 Error design FinalClass Class ZNodeComparator should be declared as final. 107
 Error coding InnerAssignment Inner assignments should be avoided. 186

org/apache/hadoop/metrics2/impl/JmxCacheBuster.java

Severity Category Rule Message Line
 Error design FinalClass Class JmxCacheBuster should be declared as final. 43

org/apache/hadoop/metrics2/lib/MutableHistogram.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'histogram' must be private and have accessor methods. 37
 Error design VisibilityModifier Variable 'name' must be private and have accessor methods. 39
 Error design VisibilityModifier Variable 'desc' must be private and have accessor methods. 40
 Error design VisibilityModifier Variable 'counter' must be private and have accessor methods. 42

org/apache/hadoop/metrics2/util/MetricQuantile.java

Severity Category Rule Message Line
 Error design VisibilityModifier Variable 'quantile' must be private and have accessor methods. 29
 Error design VisibilityModifier Variable 'error' must be private and have accessor methods. 30

org/apache/hadoop/metrics2/util/MetricSampleQuantiles.java

Severity Category Rule Message Line
 Error misc ArrayTypeStyle Array brackets at illegal position. 72
 Error design VisibilityModifier Variable 'value' must be private and have accessor methods. 283
 Error design VisibilityModifier Variable 'g' must be private and have accessor methods. 291
 Error design VisibilityModifier Variable 'delta' must be private and have accessor methods. 297

test-classes/org/apache/hadoop/hbase/PerformanceEvaluation_Counter.properties

Severity Category Rule Message Line
 Error whitespace FileTabCharacter File contains tab characters (this is the first instance). 23

Back to top

Reflow Maven skin by Andrius Velykis.