You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@accumulo.apache.org by do...@apache.org on 2022/12/16 13:50:54 UTC

[accumulo] branch main updated (14186ad915 -> 6712d2500b)

This is an automated email from the ASF dual-hosted git repository.

domgarguilo pushed a change to branch main
in repository https://gitbox.apache.org/repos/asf/accumulo.git


    from 14186ad915 Remove deprecated properties (#3106)
     add 6712d2500b Replace UtilWaitThread.sleepUninterruptibly with guava equivalent (#3121)

No new revisions were added by this update.

Summary of changes:
 .../accumulo/core/client/IsolatedScanner.java      |  2 +-
 .../core/clientImpl/ConditionalWriterImpl.java     |  2 +-
 .../accumulo/core/clientImpl/OfflineIterator.java  |  2 +-
 .../core/clientImpl/RootTabletLocator.java         |  2 +-
 .../core/clientImpl/TableOperationsImpl.java       |  2 +-
 .../core/clientImpl/TabletLocatorImpl.java         |  2 +-
 .../apache/accumulo/core/clientImpl/Writer.java    |  2 +-
 .../java/org/apache/accumulo/core/fate/Fate.java   |  3 +-
 .../org/apache/accumulo/core/fate/ZooStore.java    |  2 +-
 .../core/metadata/schema/LinkingIterator.java      |  2 +-
 .../core/rpc/clients/ManagerThriftClient.java      |  2 +-
 .../accumulo/core/rpc/clients/TServerClient.java   |  2 +-
 .../core/rpc/clients/ThriftClientTypes.java        |  2 +-
 .../java/org/apache/accumulo/core/util/Halt.java   |  2 +-
 .../apache/accumulo/core/util/UtilWaitThread.java  | 36 ----------------------
 .../accumulo/core/client/TestThrift1474.java       |  2 +-
 .../hadoopImpl/mapred/AccumuloRecordReader.java    |  2 +-
 .../hadoopImpl/mapreduce/AccumuloRecordReader.java |  2 +-
 .../its/mapreduce/AccumuloInputFormatIT.java       |  2 +-
 .../miniclusterImpl/MiniAccumuloClusterImpl.java   |  2 +-
 .../org/apache/accumulo/server/ServerContext.java  |  2 +-
 .../accumulo/server/client/BulkImporter.java       |  2 +-
 .../accumulo/server/util/ManagerMetadataUtil.java  |  2 +-
 .../accumulo/server/util/MetadataTableUtil.java    |  2 +-
 .../coordinator/CompactionCoordinator.java         |  2 +-
 .../org/apache/accumulo/compactor/Compactor.java   |  2 +-
 .../main/java/org/apache/accumulo/gc/GCRun.java    |  4 +--
 .../apache/accumulo/gc/SimpleGarbageCollector.java |  2 +-
 .../java/org/apache/accumulo/manager/Manager.java  |  2 +-
 .../manager/ManagerClientServiceHandler.java       |  2 +-
 .../accumulo/manager/TabletGroupWatcher.java       |  2 +-
 .../manager/tableOps/bulkVer1/BulkImport.java      |  2 +-
 .../manager/tableOps/bulkVer1/LoadFiles.java       |  2 +-
 .../manager/tableOps/bulkVer2/PrepBulkImport.java  |  2 +-
 server/monitor/pom.xml                             |  4 +++
 .../java/org/apache/accumulo/monitor/Monitor.java  |  2 +-
 .../org/apache/accumulo/tserver/InMemoryMap.java   |  2 +-
 .../org/apache/accumulo/tserver/ScanServer.java    |  2 +-
 .../org/apache/accumulo/tserver/TabletServer.java  |  2 +-
 .../tserver/TabletServerResourceManager.java       |  2 +-
 .../accumulo/tserver/ThriftScanClientHandler.java  |  2 +-
 .../accumulo/tserver/tablet/DatafileManager.java   |  2 +-
 .../accumulo/tserver/tablet/MinorCompactor.java    |  2 +-
 .../org/apache/accumulo/tserver/tablet/Tablet.java |  2 +-
 .../accumulo/test/BadDeleteMarkersCreatedIT.java   |  2 +-
 .../java/org/apache/accumulo/test/CleanWalIT.java  |  2 +-
 .../apache/accumulo/test/ConditionalWriterIT.java  |  2 +-
 .../accumulo/test/CountNameNodeOpsBulkIT.java      |  2 +-
 .../apache/accumulo/test/MetaGetsReadersIT.java    |  2 +-
 .../apache/accumulo/test/MultiTableRecoveryIT.java |  2 +-
 .../org/apache/accumulo/test/NamespacesIT.java     |  2 +-
 .../org/apache/accumulo/test/SplitRecoveryIT.java  |  2 +-
 .../apache/accumulo/test/TableOperationsIT.java    |  2 +-
 .../accumulo/test/TabletServerGivesUpIT.java       |  2 +-
 .../org/apache/accumulo/test/TotalQueuedIT.java    |  2 +-
 .../compaction/ExternalCompactionProgressIT.java   |  2 +-
 .../test/compaction/SplitCancelsMajCIT.java        |  2 +-
 .../accumulo/test/functional/AddSplitIT.java       |  2 +-
 .../test/functional/BadIteratorMincIT.java         |  2 +-
 .../accumulo/test/functional/BatchScanSplitIT.java |  2 +-
 .../test/functional/BatchWriterFlushIT.java        |  2 +-
 .../test/functional/BulkSplitOptimizationIT.java   |  2 +-
 .../accumulo/test/functional/CacheTestReader.java  |  2 +-
 .../accumulo/test/functional/CacheTestWriter.java  |  2 +-
 .../accumulo/test/functional/ClassLoaderIT.java    |  2 +-
 .../accumulo/test/functional/ConcurrencyIT.java    |  2 +-
 .../accumulo/test/functional/ConstraintIT.java     |  2 +-
 .../test/functional/DeleteEverythingIT.java        |  2 +-
 .../test/functional/DeleteRowsSplitIT.java         |  2 +-
 .../test/functional/GarbageCollectorIT.java        |  2 +-
 .../test/functional/HalfDeadTServerIT.java         |  2 +-
 .../accumulo/test/functional/LargeRowIT.java       |  2 +-
 .../accumulo/test/functional/MetadataIT.java       |  2 +-
 .../test/functional/MetadataMaxFilesIT.java        |  2 +-
 .../accumulo/test/functional/MetadataSplitIT.java  |  2 +-
 .../apache/accumulo/test/functional/RestartIT.java |  2 +-
 .../accumulo/test/functional/RestartStressIT.java  |  2 +-
 .../apache/accumulo/test/functional/ScanIdIT.java  |  2 +-
 .../test/functional/ScanSessionTimeOutIT.java      |  2 +-
 .../test/functional/ServerSideErrorIT.java         |  2 +-
 .../accumulo/test/functional/ShutdownIT.java       |  2 +-
 .../test/functional/SimpleBalancerFairnessIT.java  |  2 +-
 .../accumulo/test/functional/SlowConstraint.java   |  2 +-
 .../accumulo/test/functional/SlowIterator.java     |  2 +-
 .../apache/accumulo/test/functional/SplitIT.java   |  2 +-
 .../accumulo/test/functional/TabletMetadataIT.java |  2 +-
 .../apache/accumulo/test/functional/TimeoutIT.java |  2 +-
 .../accumulo/test/functional/WALSunnyDayIT.java    |  2 +-
 .../accumulo/test/functional/ZombieTServer.java    |  2 +-
 .../test/functional/ZookeeperRestartIT.java        |  2 +-
 .../accumulo/test/performance/NullTserver.java     |  2 +-
 .../apache/accumulo/test/shell/ShellServerIT.java  |  2 +-
 .../test/upgrade/GCUpgrade9to10TestIT.java         |  2 +-
 .../org/apache/accumulo/test/util/SlowOps.java     |  4 ++-
 94 files changed, 100 insertions(+), 129 deletions(-)