From commits-return-22087-archive-asf-public=cust-asf.ponee.io@accumulo.apache.org Sun Sep 9 10:24:27 2018 Return-Path: X-Original-To: archive-asf-public@cust-asf.ponee.io Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by mx-eu-01.ponee.io (Postfix) with SMTP id 23701180671 for ; Sun, 9 Sep 2018 10:24:25 +0200 (CEST) Received: (qmail 74159 invoked by uid 500); 9 Sep 2018 08:24:25 -0000 Mailing-List: contact commits-help@accumulo.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@accumulo.apache.org Delivered-To: mailing list commits@accumulo.apache.org Received: (qmail 74150 invoked by uid 99); 9 Sep 2018 08:24:25 -0000 Received: from ec2-52-202-80-70.compute-1.amazonaws.com (HELO gitbox.apache.org) (52.202.80.70) by apache.org (qpsmtpd/0.29) with ESMTP; Sun, 09 Sep 2018 08:24:25 +0000 Received: by gitbox.apache.org (ASF Mail Server at gitbox.apache.org, from userid 33) id 7CA0282A4B; Sun, 9 Sep 2018 08:24:24 +0000 (UTC) Date: Sun, 09 Sep 2018 08:24:25 +0000 To: , "' commits@accumulo.apache.org" , '@gitbox.apache.org, Subject: [accumulo] branch master updated (351193c -> f068801) MIME-Version: 1.0 Content-Type: text/plain; charset=utf-8 Content-Transfer-Encoding: 8bit Message-ID: <153648146421.9090.6477391131141161048@gitbox.apache.org> From: ctubbsii@apache.org X-Git-Host: gitbox.apache.org X-Git-Repo: accumulo X-Git-Refname: refs/heads/master X-Git-Reftype: branch X-Git-Oldrev: 351193ca869d2863c739504a451b21e03f97a797 X-Git-Newrev: f06880126cec565433a734eb7aae7ec01f763737 X-Git-NotificationType: ref_changed X-Git-Multimail-Version: 1.5.dev Auto-Submitted: auto-generated This is an automated email from the ASF dual-hosted git repository. ctubbsii pushed a change to branch master in repository https://gitbox.apache.org/repos/asf/accumulo.git. from 351193c Merge branch '1.9' new 851c2d1 Fix #639 Update JUnit usage new f068801 Merge branch '1.9' The 2 revisions listed above as "new" are entirely new to this repository and will be described in separate emails. The revisions listed as "add" were already present in the repository and have only been added to this reference. Summary of changes: .../core/client/mapred/RangeInputSplitTest.java | 27 +-- .../core/client/mapreduce/RangeInputSplitTest.java | 35 ++-- .../client/mapreduce/impl/BatchInputSplitTest.java | 25 ++- .../mapreduce/lib/impl/ConfiguratorBaseTest.java | 9 +- .../core/client/BatchWriterConfigTest.java | 11 +- .../client/admin/NewTableConfigurationTest.java | 6 +- .../core/client/impl/BulkSerializeTest.java | 5 +- .../core/client/impl/ClientConfConverterTest.java | 5 +- .../core/client/impl/ClientContextTest.java | 17 +- .../client/impl/ConcurrentKeyExtentCacheTest.java | 16 +- .../client/impl/ConditionalComparatorTest.java | 30 +-- .../accumulo/core/client/impl/ScannerImplTest.java | 3 +- .../client/impl/TableOperationsHelperTest.java | 44 ++-- .../client/lexicoder/BigIntegerLexicoderTest.java | 4 + .../core/client/lexicoder/BytesLexicoderTest.java | 2 + .../core/client/lexicoder/DateLexicoderTest.java | 2 + .../core/client/lexicoder/DoubleLexicoderTest.java | 4 + .../core/client/lexicoder/FloatLexicoderTest.java | 3 + .../client/lexicoder/IntegerLexicoderTest.java | 4 + .../core/client/lexicoder/LexicoderTest.java | 6 +- .../core/client/lexicoder/ListLexicoderTest.java | 8 +- .../core/client/lexicoder/LongLexicoderTest.java | 4 + .../core/client/lexicoder/PairLexicoderTest.java | 4 + .../client/lexicoder/ReverseLexicoderTest.java | 3 + .../core/client/lexicoder/StringLexicoderTest.java | 2 + .../core/client/lexicoder/TextLexicoderTest.java | 2 + .../client/lexicoder/UIntegerLexicoderTest.java | 4 + .../core/client/lexicoder/ULongLexicoderTest.java | 4 + .../core/client/lexicoder/UUIDLexicoderTest.java | 4 + .../lexicoder/impl/AbstractLexicoderTest.java | 3 + .../core/client/lexicoder/impl/ByteUtilsTest.java | 32 +-- .../client/security/SecurityErrorCodeTest.java | 5 +- .../tokens/CredentialProviderTokenTest.java | 23 +- .../client/security/tokens/PasswordTokenTest.java | 6 +- .../client/summary/CountingSummarizerTest.java | 46 ++-- .../summarizers/EntryLengthSummarizersTest.java | 35 ++-- .../core/conf/AccumuloConfigurationTest.java | 60 +++--- .../accumulo/core/conf/ClientPropertyTest.java | 24 ++- .../conf/CredentialProviderFactoryShimTest.java | 36 ++-- .../accumulo/core/conf/SiteConfigurationTest.java | 19 +- .../core/constraints/NoDeleteConstraintTest.java | 10 +- .../apache/accumulo/core/data/MutationTest.java | 55 +++-- .../org/apache/accumulo/core/data/RangeTest.java | 58 +++++- .../blockfile/cache/BlockCacheFactoryTest.java | 5 +- .../blockfile/cache/BlockCacheManagerTest.java | 11 +- .../file/blockfile/cache/TestCachedBlockQueue.java | 9 +- .../file/blockfile/cache/TestLruBlockCache.java | 30 ++- .../accumulo/core/file/rfile/BlockIndexTest.java | 23 +- .../accumulo/core/file/rfile/KeyShortenerTest.java | 22 +- .../core/file/rfile/MultiLevelIndexTest.java | 9 +- .../apache/accumulo/core/file/rfile/RFileTest.java | 30 ++- .../core/file/rfile/RolllingStatsTest.java | 17 +- .../core/file/rfile/bcfile/CompressionTest.java | 46 ++-- .../file/streams/RateLimitedInputStreamTest.java | 7 +- .../file/streams/RateLimitedOutputStreamTest.java | 7 +- .../accumulo/core/iterators/IteratorUtilTest.java | 13 +- .../system/ColumnFamilySkippingIteratorTest.java | 12 +- .../core/iterators/system/ColumnFilterTest.java | 32 +-- .../iterators/system/DeletingIteratorTest.java | 15 +- .../core/iterators/system/MultiIteratorTest.java | 16 +- .../system/SourceSwitchingIteratorTest.java | 18 +- .../iterators/system/VisibilityFilterTest.java | 11 +- .../accumulo/core/iterators/user/CombinerTest.java | 13 +- .../iterators/user/IndexedDocIteratorTest.java | 17 +- .../core/iterators/user/LargeRowFilterTest.java | 13 +- .../iterators/user/RowDeletingIteratorTest.java | 13 +- .../iterators/user/TransformingIteratorTest.java | 9 +- .../user/WholeColumnFamilyIteratorTest.java | 15 +- .../core/metadata/schema/LinkingIteratorTest.java | 4 +- .../ReplicationConfigurationUtilTest.java | 17 +- .../core/replication/ReplicationSchemaTest.java | 23 +- .../core/replication/ReplicationTargetTest.java | 20 +- .../spi/scan/IdleRatioScanPrioritizerTest.java | 15 +- .../core/spi/scan/SimpleScanDispatcherTest.java | 12 +- .../core/summary/SummaryCollectionTest.java | 17 +- .../accumulo/core/util/ByteBufferUtilTest.java | 38 ++-- .../core/util/CompletableFutureUtilTest.java | 7 +- .../apache/accumulo/core/util/FastFormatTest.java | 54 ++--- .../apache/accumulo/core/util/PartitionerTest.java | 9 +- .../apache/accumulo/core/util/TextUtilTest.java | 13 +- .../core/util/UnsynchronizedBufferTest.java | 6 +- .../core/volume/NonConfiguredVolumeTest.java | 9 +- .../org/apache/accumulo/fate/AgeOffStoreTest.java | 38 ++-- .../apache/accumulo/fate/ReadOnlyStoreTest.java | 20 +- .../apache/accumulo/fate/util/AddressUtilTest.java | 12 +- .../org/apache/accumulo/fate/util/RetryTest.java | 63 +++--- .../fate/zookeeper/TransactionWatcherTest.java | 33 +-- .../zookeeper/ZooKeeperConnectionInfoTest.java | 7 +- .../fate/zookeeper/ZooReaderWriterTest.java | 7 +- .../minicluster/MiniAccumuloClusterTest.java | 34 +-- .../impl/MiniAccumuloClusterImplTest.java | 27 +-- pom.xml | 8 + .../org/apache/accumulo/proxy/ProxyServerTest.java | 6 +- .../accumulo/server/ServerConstantsTest.java | 16 +- .../apache/accumulo/server/ServerContextTest.java | 9 +- .../org/apache/accumulo/server/ServerOptsTest.java | 5 +- .../accumulo/server/client/BulkImporterTest.java | 34 +-- .../org/apache/accumulo/server/fs/FileRefTest.java | 69 +++--- .../apache/accumulo/server/fs/FileTypeTest.java | 60 +++--- .../apache/accumulo/server/fs/ViewFSUtilsTest.java | 19 +- .../accumulo/server/fs/VolumeManagerImplTest.java | 11 +- .../apache/accumulo/server/fs/VolumeUtilTest.java | 127 +++++------ .../iterators/MetadataBulkLoadFilterTest.java | 5 +- .../server/master/balancer/GroupBalancerTest.java | 18 +- ...tRegexTableLoadBalancerReconfigurationTest.java | 16 +- .../balancer/HostRegexTableLoadBalancerTest.java | 232 ++++++++++----------- .../master/balancer/TableLoadBalancerTest.java | 8 +- .../server/replication/StatusCombinerTest.java | 64 +++--- .../server/replication/StatusUtilTest.java | 16 +- .../server/replication/proto/StatusTest.java | 11 +- .../TCredentialsUpdatingInvocationHandlerTest.java | 7 +- .../security/handler/ZKAuthenticatorTest.java | 14 +- .../apache/accumulo/server/util/FileUtilTest.java | 27 +-- .../server/util/ReplicationTableUtilTest.java | 28 +-- .../apache/accumulo/gc/GarbageCollectionTest.java | 29 ++- ...DistributedWorkQueueWorkAssignerHelperTest.java | 7 +- .../MasterReplicationCoordinatorTest.java | 11 +- .../replication/SequentialWorkAssignerTest.java | 6 +- .../replication/UnorderedWorkAssignerTest.java | 16 +- .../accumulo/master/replication/WorkMakerTest.java | 13 +- .../master/state/RootTabletStateStoreTest.java | 7 +- .../accumulo/master/tableOps/ImportTableTest.java | 5 +- .../tableOps/bulkVer2/PrepBulkImportTest.java | 8 +- .../accumulo/monitor/ShowTraceLinkTypeTest.java | 5 +- .../accumulo/monitor/ZooKeeperStatusTest.java | 7 +- .../org/apache/accumulo/monitor/it/WebViewsIT.java | 13 +- .../monitor/util/AccumuloMonitorAppenderTest.java | 32 +-- .../monitor/util/ParameterValidatorTest.java | 43 ++-- .../accumulo/tserver/CheckTabletMetadataTest.java | 14 +- .../accumulo/tserver/CountingIteratorTest.java | 5 +- .../apache/accumulo/tserver/InMemoryMapTest.java | 11 +- .../org/apache/accumulo/tserver/MemValueTest.java | 5 +- .../accumulo/tserver/WalRemovalOrderTest.java | 5 +- .../SizeLimitCompactionStrategyTest.java | 16 +- .../compaction/TwoTierCompactionStrategyTest.java | 39 ++-- .../ConfigurableCompactionStrategyTest.java | 23 +- .../apache/accumulo/tserver/log/LogEventsTest.java | 5 +- .../accumulo/tserver/log/LogFileKeyTest.java | 13 +- .../tserver/log/SortedLogRecoveryTest.java | 166 +++++++-------- .../replication/AccumuloReplicaSystemTest.java | 63 +++--- .../replication/ReplicationProcessorTest.java | 4 +- .../accumulo/tserver/tablet/RootFilesTest.java | 6 +- .../apache/accumulo/tserver/tablet/TabletTest.java | 14 +- .../shell/commands/DeleteTableCommandTest.java | 5 +- .../classloader/vfs/AccumuloClasspathTest.java | 17 +- .../vfs/AccumuloReloadingVFSClassLoaderTest.java | 57 ++--- .../vfs/AccumuloVFSClassLoaderTest.java | 30 +-- .../start/classloader/vfs/ContextManagerTest.java | 21 +- .../vfs/providers/VfsClassLoaderTest.java | 12 +- .../org/apache/accumulo/harness/TestingKdc.java | 7 +- .../accumulo/test/ArbitraryTablePropertiesIT.java | 27 +-- .../accumulo/test/BadDeleteMarkersCreatedIT.java | 10 +- .../accumulo/test/BatchWriterInTabletServerIT.java | 13 +- .../accumulo/test/CompactionRateLimitingIT.java | 5 +- .../apache/accumulo/test/ConditionalWriterIT.java | 210 +++++++++---------- .../org/apache/accumulo/test/ExistingMacIT.java | 7 +- .../org/apache/accumulo/test/ImportExportIT.java | 31 +-- .../accumulo/test/InterruptibleScannersIT.java | 5 +- .../accumulo/test/IsolationAndDeepCopyIT.java | 11 +- .../apache/accumulo/test/KeyValueEqualityIT.java | 12 +- .../org/apache/accumulo/test/LargeSplitRowIT.java | 44 ++-- .../java/org/apache/accumulo/test/LocatorIT.java | 20 +- .../test/MissingWalHeaderCompletesRecoveryIT.java | 16 +- .../accumulo/test/MultiTableBatchWriterIT.java | 23 +- .../accumulo/test/NewTableConfigurationIT.java | 30 +-- .../test/RecoveryCompactionsAreFlushesIT.java | 5 +- .../java/org/apache/accumulo/test/SampleIT.java | 22 +- .../org/apache/accumulo/test/ShellConfigIT.java | 9 +- .../org/apache/accumulo/test/ShellServerIT.java | 9 +- .../accumulo/test/TableConfigurationUpdateIT.java | 8 +- .../apache/accumulo/test/TableOperationsIT.java | 9 +- .../accumulo/test/UserCompactionStrategyIT.java | 40 ++-- .../java/org/apache/accumulo/test/VolumeIT.java | 44 ++-- .../org/apache/accumulo/test/YieldScannersIT.java | 31 ++- .../BalanceInPresenceOfOfflineTableIT.java | 4 +- .../test/functional/BatchWriterFlushIT.java | 12 +- .../accumulo/test/functional/BulkLoadIT.java | 9 +- .../apache/accumulo/test/functional/CleanUpIT.java | 18 +- .../accumulo/test/functional/CloneTestIT.java | 26 +-- .../test/functional/ConcurrentDeleteTableIT.java | 10 +- .../test/functional/ConfigurableCompactionIT.java | 4 +- .../accumulo/test/functional/ConnectorIT.java | 52 ++--- .../accumulo/test/functional/CreateAndUseIT.java | 11 +- .../test/functional/CreateInitialSplitsIT.java | 1 - .../accumulo/test/functional/DeleteFailIT.java | 5 +- .../test/functional/DeleteTableDuringSplitIT.java | 6 +- .../test/functional/FunctionalTestUtils.java | 6 +- .../test/functional/GarbageCollectorIT.java | 27 +-- .../accumulo/test/functional/KerberosProxyIT.java | 8 +- .../accumulo/test/functional/LargeRowIT.java | 4 +- .../accumulo/test/functional/MetadataIT.java | 8 +- .../accumulo/test/functional/NativeMapIT.java | 3 +- .../accumulo/test/functional/PermissionsIT.java | 3 +- .../apache/accumulo/test/functional/RestartIT.java | 4 +- .../apache/accumulo/test/functional/ScannerIT.java | 5 +- .../apache/accumulo/test/functional/SummaryIT.java | 154 +++++++------- .../accumulo/test/functional/TooManyDeletesIT.java | 17 +- .../accumulo/test/functional/WALSunnyDayIT.java | 3 +- .../CloseWriteAheadLogReferencesIT.java | 9 +- .../test/mapred/AccumuloInputFormatIT.java | 27 ++- .../test/mapreduce/AccumuloInputFormatIT.java | 27 ++- .../apache/accumulo/test/master/MergeStateIT.java | 15 +- .../accumulo/test/master/SuspendedTabletsIT.java | 17 +- .../test/replication/CyclicReplicationIT.java | 19 +- .../test/replication/FinishedWorkUpdaterIT.java | 21 +- ...GarbageCollectorCommunicatesWithTServersIT.java | 59 +++--- .../test/replication/KerberosReplicationIT.java | 13 +- .../replication/MultiInstanceReplicationIT.java | 76 +++---- .../replication/MultiTserverReplicationIT.java | 20 +- .../RemoveCompleteReplicationRecordsIT.java | 28 +-- .../accumulo/test/replication/ReplicationIT.java | 154 +++++++------- .../replication/ReplicationOperationsImplIT.java | 43 ++-- .../test/replication/SequentialWorkAssignerIT.java | 53 ++--- .../test/replication/StatusCombinerMacIT.java | 22 +- .../accumulo/test/replication/StatusMakerIT.java | 59 +++--- .../UnorderedWorkAssignerReplicationIT.java | 80 +++---- .../UnusedWalDoesntCloseReplicationStatusIT.java | 10 +- .../accumulo/test/replication/WorkMakerIT.java | 30 +-- .../apache/accumulo/test/rpc/ThriftBehaviorIT.java | 20 +- .../accumulo/test/fate/zookeeper/ZooLockTest.java | 95 +++++---- 220 files changed, 2756 insertions(+), 2335 deletions(-)