You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@distributedlog.apache.org by si...@apache.org on 2017/01/05 00:51:56 UTC

[51/51] [partial] incubator-distributedlog git commit: DL-4: Repackage the source under apache namespace

DL-4: Repackage the source under apache namespace


Project: http://git-wip-us.apache.org/repos/asf/incubator-distributedlog/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-distributedlog/commit/b44820b5
Tree: http://git-wip-us.apache.org/repos/asf/incubator-distributedlog/tree/b44820b5
Diff: http://git-wip-us.apache.org/repos/asf/incubator-distributedlog/diff/b44820b5

Branch: refs/heads/master
Commit: b44820b50eea9ef2447ec7e136e182ba39e2c269
Parents: 7fab246
Author: Sijie Guo <si...@twitter.com>
Authored: Wed Jan 4 16:44:15 2017 -0800
Committer: Sijie Guo <si...@twitter.com>
Committed: Wed Jan 4 16:46:19 2017 -0800

----------------------------------------------------------------------
 distributedlog-benchmark/conf/log4j.properties  |    8 +-
 .../distributedlog/benchmark/Benchmarker.java   |  468 ---
 .../benchmark/DLWriterWorker.java               |  245 --
 .../distributedlog/benchmark/ReaderWorker.java  |  468 ---
 .../twitter/distributedlog/benchmark/Utils.java |   57 -
 .../distributedlog/benchmark/Worker.java        |   26 -
 .../distributedlog/benchmark/WriterWorker.java  |  387 --
 .../distributedlog/benchmark/package-info.java  |   21 -
 .../stream/AbstractReaderBenchmark.java         |   70 -
 .../benchmark/stream/AsyncReaderBenchmark.java  |  158 -
 .../benchmark/stream/LedgerBatchReader.java     |   82 -
 .../benchmark/stream/LedgerReadBenchmark.java   |  151 -
 .../benchmark/stream/LedgerStreamReader.java    |  131 -
 .../benchmark/stream/ReadMode.java              |   28 -
 .../benchmark/stream/StreamBenchmark.java       |  138 -
 .../benchmark/stream/SyncReaderBenchmark.java   |  164 -
 .../benchmark/stream/package-info.java          |   21 -
 .../benchmark/utils/ShiftableRateLimiter.java   |   71 -
 .../benchmark/utils/package-info.java           |   21 -
 .../distributedlog/benchmark/Benchmarker.java   |  468 +++
 .../benchmark/DLWriterWorker.java               |  245 ++
 .../distributedlog/benchmark/ReaderWorker.java  |  468 +++
 .../apache/distributedlog/benchmark/Utils.java  |   57 +
 .../apache/distributedlog/benchmark/Worker.java |   26 +
 .../distributedlog/benchmark/WriterWorker.java  |  387 ++
 .../distributedlog/benchmark/package-info.java  |   21 +
 .../stream/AbstractReaderBenchmark.java         |   70 +
 .../benchmark/stream/AsyncReaderBenchmark.java  |  158 +
 .../benchmark/stream/LedgerBatchReader.java     |   82 +
 .../benchmark/stream/LedgerReadBenchmark.java   |  151 +
 .../benchmark/stream/LedgerStreamReader.java    |  131 +
 .../benchmark/stream/ReadMode.java              |   28 +
 .../benchmark/stream/StreamBenchmark.java       |  138 +
 .../benchmark/stream/SyncReaderBenchmark.java   |  164 +
 .../benchmark/stream/package-info.java          |   21 +
 .../benchmark/utils/ShiftableRateLimiter.java   |   71 +
 .../benchmark/utils/package-info.java           |   21 +
 .../src/main/resources/findbugsExclude.xml      |    2 +-
 .../src/main/thrift/loadtest.thrift             |    2 +-
 distributedlog-client/pom.xml                   |    2 +-
 .../distributedlog/client/ClientConfig.java     |  187 -
 .../client/DistributedLogClientImpl.java        | 1200 ------
 .../client/DistributedLogMultiStreamWriter.java |  486 ---
 .../client/monitor/MonitorServiceClient.java    |   68 -
 .../client/monitor/package-info.java            |   21 -
 .../client/ownership/OwnershipCache.java        |  235 --
 .../client/ownership/package-info.java          |   21 -
 .../distributedlog/client/package-info.java     |   21 -
 .../client/proxy/ClusterClient.java             |   51 -
 .../client/proxy/HostProvider.java              |   35 -
 .../client/proxy/ProxyClient.java               |  165 -
 .../client/proxy/ProxyClientManager.java        |  362 --
 .../client/proxy/ProxyListener.java             |   50 -
 .../client/proxy/package-info.java              |   21 -
 .../client/resolver/DefaultRegionResolver.java  |   85 -
 .../client/resolver/RegionResolver.java         |   43 -
 .../client/resolver/package-info.java           |   21 -
 .../routing/ConsistentHashRoutingService.java   |  500 ---
 .../client/routing/NameServerSet.java           |  263 --
 .../client/routing/RegionsRoutingService.java   |  192 -
 .../client/routing/RoutingService.java          |  206 -
 .../client/routing/RoutingServiceProvider.java  |   39 -
 .../client/routing/RoutingUtils.java            |   88 -
 .../client/routing/ServerSetRoutingService.java |  274 --
 .../client/routing/ServerSetWatcher.java        |   71 -
 .../routing/SingleHostRoutingService.java       |  128 -
 .../distributedlog/client/routing/TestName.java |   49 -
 .../client/routing/TwitterServerSetWatcher.java |   83 -
 .../client/routing/package-info.java            |   21 -
 .../client/serverset/DLZkServerSet.java         |   91 -
 .../client/serverset/package-info.java          |   21 -
 ...efaultSpeculativeRequestExecutionPolicy.java |  119 -
 .../SpeculativeRequestExecutionPolicy.java      |   34 -
 .../speculative/SpeculativeRequestExecutor.java |   33 -
 .../client/speculative/package-info.java        |   21 -
 .../client/stats/ClientStats.java               |  108 -
 .../client/stats/ClientStatsLogger.java         |   91 -
 .../distributedlog/client/stats/OpStats.java    |   82 -
 .../client/stats/OpStatsLogger.java             |   50 -
 .../client/stats/OwnershipStatsLogger.java      |  115 -
 .../client/stats/package-info.java              |   21 -
 .../distributedlog/service/DLSocketAddress.java |  161 -
 .../service/DistributedLogClient.java           |  108 -
 .../service/DistributedLogClientBuilder.java    |  608 ---
 .../distributedlog/service/package-info.java    |   21 -
 .../distributedlog/client/ClientConfig.java     |  187 +
 .../client/DistributedLogClientImpl.java        | 1200 ++++++
 .../client/DistributedLogMultiStreamWriter.java |  486 +++
 .../client/monitor/MonitorServiceClient.java    |   68 +
 .../client/monitor/package-info.java            |   21 +
 .../client/ownership/OwnershipCache.java        |  235 ++
 .../client/ownership/package-info.java          |   21 +
 .../distributedlog/client/package-info.java     |   21 +
 .../client/proxy/ClusterClient.java             |   51 +
 .../client/proxy/HostProvider.java              |   35 +
 .../client/proxy/ProxyClient.java               |  165 +
 .../client/proxy/ProxyClientManager.java        |  362 ++
 .../client/proxy/ProxyListener.java             |   50 +
 .../client/proxy/package-info.java              |   21 +
 .../client/resolver/DefaultRegionResolver.java  |   85 +
 .../client/resolver/RegionResolver.java         |   43 +
 .../client/resolver/package-info.java           |   21 +
 .../routing/ConsistentHashRoutingService.java   |  500 +++
 .../client/routing/NameServerSet.java           |  263 ++
 .../client/routing/RegionsRoutingService.java   |  192 +
 .../client/routing/RoutingService.java          |  206 +
 .../client/routing/RoutingServiceProvider.java  |   39 +
 .../client/routing/RoutingUtils.java            |   88 +
 .../client/routing/ServerSetRoutingService.java |  274 ++
 .../client/routing/ServerSetWatcher.java        |   71 +
 .../routing/SingleHostRoutingService.java       |  128 +
 .../distributedlog/client/routing/TestName.java |   49 +
 .../client/routing/TwitterServerSetWatcher.java |   83 +
 .../client/routing/package-info.java            |   21 +
 .../client/serverset/DLZkServerSet.java         |   91 +
 .../client/serverset/package-info.java          |   21 +
 ...efaultSpeculativeRequestExecutionPolicy.java |  119 +
 .../SpeculativeRequestExecutionPolicy.java      |   34 +
 .../speculative/SpeculativeRequestExecutor.java |   33 +
 .../client/speculative/package-info.java        |   21 +
 .../client/stats/ClientStats.java               |  108 +
 .../client/stats/ClientStatsLogger.java         |   91 +
 .../distributedlog/client/stats/OpStats.java    |   82 +
 .../client/stats/OpStatsLogger.java             |   50 +
 .../client/stats/OwnershipStatsLogger.java      |  115 +
 .../client/stats/package-info.java              |   21 +
 .../distributedlog/service/DLSocketAddress.java |  161 +
 .../service/DistributedLogClient.java           |  108 +
 .../service/DistributedLogClientBuilder.java    |  608 +++
 .../distributedlog/service/package-info.java    |   21 +
 .../src/main/resources/findbugsExclude.xml      |    2 +-
 .../TestDistributedLogMultiStreamWriter.java    |  383 --
 .../client/ownership/TestOwnershipCache.java    |  207 -
 .../proxy/MockDistributedLogServices.java       |  144 -
 .../client/proxy/MockProxyClientBuilder.java    |   49 -
 .../client/proxy/MockThriftClient.java          |   32 -
 .../client/proxy/TestProxyClientManager.java    |  368 --
 .../TestConsistentHashRoutingService.java       |  417 ---
 .../client/routing/TestInetNameResolution.java  |   73 -
 .../routing/TestRegionsRoutingService.java      |  133 -
 .../client/routing/TestRoutingService.java      |  146 -
 ...efaultSpeculativeRequestExecutionPolicy.java |  105 -
 .../TestDistributedLogClientBuilder.java        |   49 -
 .../TestDistributedLogMultiStreamWriter.java    |  383 ++
 .../client/ownership/TestOwnershipCache.java    |  207 +
 .../proxy/MockDistributedLogServices.java       |  144 +
 .../client/proxy/MockProxyClientBuilder.java    |   49 +
 .../client/proxy/MockThriftClient.java          |   32 +
 .../client/proxy/TestProxyClientManager.java    |  368 ++
 .../TestConsistentHashRoutingService.java       |  417 +++
 .../client/routing/TestInetNameResolution.java  |   73 +
 .../routing/TestRegionsRoutingService.java      |  133 +
 .../client/routing/TestRoutingService.java      |  146 +
 ...efaultSpeculativeRequestExecutionPolicy.java |  105 +
 .../TestDistributedLogClientBuilder.java        |   49 +
 distributedlog-core/conf/log4j.properties       |    8 +-
 .../conf/zookeeper.conf.dynamic.template        |    2 +-
 distributedlog-core/pom.xml                     |    2 +-
 .../distributedlog/AppendOnlyStreamReader.java  |  198 -
 .../distributedlog/AppendOnlyStreamWriter.java  |  107 -
 .../twitter/distributedlog/AsyncLogReader.java  |   69 -
 .../twitter/distributedlog/AsyncLogWriter.java  |   70 -
 .../distributedlog/AsyncNotification.java       |   32 -
 .../distributedlog/BKAbstractLogWriter.java     |  555 ---
 .../distributedlog/BKAsyncLogReader.java        |  751 ----
 .../distributedlog/BKAsyncLogWriter.java        |  559 ---
 .../distributedlog/BKDistributedLogManager.java | 1106 ------
 .../BKDistributedLogNamespace.java              |  320 --
 .../twitter/distributedlog/BKLogHandler.java    |  715 ----
 .../distributedlog/BKLogReadHandler.java        |  431 ---
 .../distributedlog/BKLogSegmentWriter.java      | 1348 -------
 .../distributedlog/BKLogWriteHandler.java       | 1325 -------
 .../twitter/distributedlog/BKSyncLogReader.java |  276 --
 .../twitter/distributedlog/BKSyncLogWriter.java |  113 -
 .../distributedlog/BKTransmitPacket.java        |   90 -
 .../distributedlog/BookKeeperClient.java        |  289 --
 .../distributedlog/BookKeeperClientBuilder.java |  209 --
 .../DistributedLogConfiguration.java            | 3528 ------------------
 .../distributedlog/DistributedLogConstants.java |   69 -
 .../distributedlog/DistributedLogManager.java   |  308 --
 .../java/com/twitter/distributedlog/Entry.java  |  403 --
 .../com/twitter/distributedlog/EntryBuffer.java |   70 -
 .../twitter/distributedlog/EntryPosition.java   |   63 -
 .../twitter/distributedlog/EnvelopedEntry.java  |  296 --
 .../distributedlog/EnvelopedEntryReader.java    |  102 -
 .../distributedlog/EnvelopedEntryWriter.java    |  192 -
 .../distributedlog/LedgerReadPosition.java      |  171 -
 .../distributedlog/LocalDLMEmulator.java        |  364 --
 .../com/twitter/distributedlog/LogReader.java   |  195 -
 .../distributedlog/LogSegmentMetadata.java      | 1125 ------
 .../com/twitter/distributedlog/LogWriter.java   |   78 -
 .../distributedlog/MaxLogSegmentSequenceNo.java |   72 -
 .../com/twitter/distributedlog/MaxTxId.java     |   72 -
 .../distributedlog/MetadataAccessor.java        |   43 -
 .../distributedlog/ReadAheadEntryReader.java    |  992 -----
 .../com/twitter/distributedlog/ReadUtils.java   |  782 ----
 .../twitter/distributedlog/WriteLimiter.java    |   62 -
 .../twitter/distributedlog/ZooKeeperClient.java |  402 --
 .../distributedlog/ZooKeeperClientBuilder.java  |  233 --
 .../acl/AccessControlManager.java               |   74 -
 .../acl/DefaultAccessControlManager.java        |   55 -
 .../distributedlog/acl/package-info.java        |   21 -
 .../admin/DistributedLogAdmin.java              |  921 -----
 .../distributedlog/admin/package-info.java      |   21 -
 .../distributedlog/auditor/DLAuditor.java       |  630 ----
 .../bk/DynamicQuorumConfigProvider.java         |   37 -
 .../bk/ImmutableQuorumConfigProvider.java       |   35 -
 .../distributedlog/bk/LedgerAllocator.java      |   32 -
 .../bk/LedgerAllocatorDelegator.java            |   83 -
 .../distributedlog/bk/LedgerAllocatorPool.java  |  458 ---
 .../distributedlog/bk/LedgerAllocatorUtils.java |   54 -
 .../twitter/distributedlog/bk/QuorumConfig.java |   92 -
 .../distributedlog/bk/QuorumConfigProvider.java |   32 -
 .../bk/SimpleLedgerAllocator.java               |  536 ---
 .../twitter/distributedlog/bk/package-info.java |   24 -
 .../callback/LogSegmentListener.java            |   42 -
 .../callback/LogSegmentNamesListener.java       |   42 -
 .../callback/NamespaceListener.java             |   34 -
 .../callback/ReadAheadCallback.java             |   25 -
 .../distributedlog/callback/package-info.java   |   21 -
 .../config/ConcurrentBaseConfiguration.java     |   76 -
 .../config/ConcurrentConstConfiguration.java    |   31 -
 .../config/ConfigurationListener.java           |   32 -
 .../config/ConfigurationSubscription.java       |  186 -
 .../config/DynamicConfigurationFactory.java     |   91 -
 .../DynamicDistributedLogConfiguration.java     |  356 --
 .../config/FileConfigurationBuilder.java        |   28 -
 .../config/PropertiesConfigurationBuilder.java  |   40 -
 .../distributedlog/config/package-info.java     |   21 -
 .../distributedlog/exceptions/ZKException.java  |   54 -
 .../feature/AbstractFeatureProvider.java        |  103 -
 .../feature/ConfigurationFeatureProvider.java   |   76 -
 .../distributedlog/feature/CoreFeatureKeys.java |   29 -
 .../feature/DefaultFeatureProvider.java         |   47 -
 .../DynamicConfigurationFeatureProvider.java    |  132 -
 .../distributedlog/feature/package-info.java    |   21 -
 .../function/CloseAsyncCloseableFunction.java   |   51 -
 .../function/DefaultValueMapFunction.java       |   41 -
 .../function/GetLastTxIdFunction.java           |   43 -
 .../function/GetVersionedValueFunction.java     |   39 -
 .../distributedlog/function/VoidFunctions.java  |   34 -
 .../distributedlog/function/package-info.java   |   21 -
 .../distributedlog/impl/BKNamespaceDriver.java  |  631 ----
 .../distributedlog/impl/ZKLogMetadataStore.java |  124 -
 .../impl/ZKLogSegmentFilters.java               |   89 -
 .../impl/ZKLogSegmentMetadataStore.java         |  503 ---
 .../distributedlog/impl/ZKMetadataAccessor.java |  264 --
 .../distributedlog/impl/ZKNamespaceWatcher.java |  133 -
 .../impl/acl/ZKAccessControl.java               |  232 --
 .../impl/acl/ZKAccessControlManager.java        |  374 --
 .../federated/FederatedZKLogMetadataStore.java  |  760 ----
 .../impl/logsegment/BKLogSegmentAllocator.java  |   85 -
 .../logsegment/BKLogSegmentEntryReader.java     |  837 -----
 .../impl/logsegment/BKLogSegmentEntryStore.java |  286 --
 .../logsegment/BKLogSegmentEntryWriter.java     |   61 -
 .../BKLogSegmentRandomAccessEntryReader.java    |  119 -
 .../distributedlog/impl/logsegment/BKUtils.java |   72 -
 .../impl/metadata/BKDLConfig.java               |  400 --
 .../impl/metadata/ZKLogStreamMetadataStore.java |  633 ----
 .../impl/metadata/ZkMetadataResolver.java       |   72 -
 .../distributedlog/impl/package-info.java       |   21 -
 .../subscription/ZKSubscriptionStateStore.java  |  121 -
 .../impl/subscription/ZKSubscriptionsStore.java |  164 -
 .../injector/AsyncFailureInjector.java          |  131 -
 .../injector/AsyncRandomFailureInjector.java    |  186 -
 .../injector/FailureInjector.java               |   37 -
 .../injector/RandomDelayFailureInjector.java    |   60 -
 .../distributedlog/injector/package-info.java   |   21 -
 .../twitter/distributedlog/io/Abortable.java    |   41 -
 .../twitter/distributedlog/io/Abortables.java   |  183 -
 .../distributedlog/io/AsyncAbortable.java       |   57 -
 .../distributedlog/io/AsyncCloseable.java       |   60 -
 .../distributedlog/io/AsyncDeleteable.java      |   34 -
 .../twitter/distributedlog/io/package-info.java |   21 -
 .../limiter/ChainedRequestLimiter.java          |   76 -
 .../limiter/ComposableRequestLimiter.java       |   73 -
 .../limiter/GuavaRateLimiter.java               |   58 -
 .../distributedlog/limiter/RateLimiter.java     |   49 -
 .../distributedlog/limiter/RequestLimiter.java  |   24 -
 .../distributedlog/limiter/package-info.java    |   21 -
 .../distributedlog/lock/DistributedLock.java    |   54 -
 .../lock/DistributedLockContext.java            |   43 -
 .../lock/EpochChangedException.java             |   33 -
 .../twitter/distributedlog/lock/LockAction.java |   36 -
 .../lock/LockClosedException.java               |   38 -
 .../distributedlog/lock/LockListener.java       |   28 -
 .../lock/LockSessionExpiredException.java       |   34 -
 .../lock/LockStateChangedException.java         |   36 -
 .../lock/LockTimeoutException.java              |   34 -
 .../twitter/distributedlog/lock/LockWaiter.java |   95 -
 .../distributedlog/lock/NopDistributedLock.java |   51 -
 .../distributedlog/lock/SessionLock.java        |  126 -
 .../distributedlog/lock/SessionLockFactory.java |   38 -
 .../distributedlog/lock/ZKDistributedLock.java  |  537 ---
 .../distributedlog/lock/ZKSessionLock.java      | 1363 -------
 .../lock/ZKSessionLockFactory.java              |  133 -
 .../distributedlog/lock/package-info.java       |   21 -
 .../logsegment/LogSegmentEntryReader.java       |  113 -
 .../logsegment/LogSegmentEntryStore.java        |   73 -
 .../logsegment/LogSegmentEntryWriter.java       |   72 -
 .../logsegment/LogSegmentFilter.java            |   42 -
 .../logsegment/LogSegmentMetadataCache.java     |   98 -
 .../logsegment/LogSegmentMetadataStore.java     |  163 -
 .../LogSegmentRandomAccessEntryReader.java      |   47 -
 .../logsegment/LogSegmentWriter.java            |   87 -
 .../logsegment/PerStreamLogSegmentCache.java    |  243 --
 .../logsegment/RollingPolicy.java               |   33 -
 .../logsegment/SizeBasedRollingPolicy.java      |   34 -
 .../logsegment/TimeBasedRollingPolicy.java      |   46 -
 .../distributedlog/logsegment/package-info.java |   21 -
 .../distributedlog/metadata/DLConfig.java       |   39 -
 .../distributedlog/metadata/DLMetadata.java     |  227 --
 .../DryrunLogSegmentMetadataStoreUpdater.java   |   51 -
 .../distributedlog/metadata/LogMetadata.java    |  175 -
 .../metadata/LogMetadataForReader.java          |  103 -
 .../metadata/LogMetadataForWriter.java          |   64 -
 .../metadata/LogMetadataStore.java              |   66 -
 .../LogSegmentMetadataStoreUpdater.java         |  184 -
 .../metadata/LogStreamMetadataStore.java        |  114 -
 .../metadata/MetadataResolver.java              |   51 -
 .../metadata/MetadataUpdater.java               |  120 -
 .../distributedlog/metadata/package-info.java   |   21 -
 .../namespace/DistributedLogNamespace.java      |  190 -
 .../DistributedLogNamespaceBuilder.java         |  278 --
 .../namespace/NamespaceDriver.java              |  138 -
 .../namespace/NamespaceDriverManager.java       |  180 -
 .../namespace/NamespaceWatcher.java             |   61 -
 .../distributedlog/namespace/package-info.java  |   21 -
 .../twitter/distributedlog/net/DNSResolver.java |  113 -
 .../distributedlog/net/DNSResolverForRacks.java |   66 -
 .../distributedlog/net/DNSResolverForRows.java  |   72 -
 .../twitter/distributedlog/net/NetUtils.java    |   74 -
 .../distributedlog/net/package-info.java        |   33 -
 .../twitter/distributedlog/package-info.java    |   21 -
 .../distributedlog/rate/MovingAverageRate.java  |   24 -
 .../rate/MovingAverageRateFactory.java          |   65 -
 .../rate/SampledMovingAverageRate.java          |   58 -
 .../distributedlog/readahead/package-info.java  |   21 -
 .../selector/FirstDLSNNotLessThanSelector.java  |   46 -
 .../selector/FirstRecordSelector.java           |   46 -
 .../selector/FirstTxIdNotLessThanSelector.java  |   51 -
 .../selector/LastRecordSelector.java            |   38 -
 .../selector/LogRecordSelector.java             |   40 -
 .../stats/BKExceptionStatsLogger.java           |  109 -
 .../stats/BroadCastStatsLogger.java             |  194 -
 .../distributedlog/stats/OpStatsListener.java   |   51 -
 .../subscription/SubscriptionStateStore.java    |   42 -
 .../subscription/SubscriptionsStore.java        |   69 -
 .../tools/DistributedLogTool.java               | 2873 --------------
 .../com/twitter/distributedlog/tools/Tool.java  |  243 --
 .../distributedlog/tools/package-info.java      |   21 -
 .../twitter/distributedlog/util/Allocator.java  |  102 -
 .../distributedlog/util/CommandLineUtils.java   |   56 -
 .../twitter/distributedlog/util/ConfUtils.java  |   65 -
 .../twitter/distributedlog/util/DLUtils.java    |  321 --
 .../distributedlog/util/FailpointUtils.java     |  134 -
 .../distributedlog/util/FutureUtils.java        |  534 ---
 .../util/MonitoredFuturePool.java               |  131 -
 .../MonitoredScheduledThreadPoolExecutor.java   |  257 --
 .../distributedlog/util/OrderedScheduler.java   |  490 ---
 .../distributedlog/util/PermitLimiter.java      |   57 -
 .../distributedlog/util/PermitManager.java      |   93 -
 .../distributedlog/util/RetryPolicyUtils.java   |   45 -
 .../util/SafeQueueingFuturePool.java            |  115 -
 .../distributedlog/util/SchedulerUtils.java     |   56 -
 .../twitter/distributedlog/util/Sequencer.java  |   31 -
 .../util/SimplePermitLimiter.java               |  117 -
 .../twitter/distributedlog/util/Sizable.java    |   31 -
 .../distributedlog/util/TimeSequencer.java      |   39 -
 .../distributedlog/util/Transaction.java        |   97 -
 .../com/twitter/distributedlog/util/Utils.java  |  607 ---
 .../distributedlog/util/package-info.java       |   21 -
 .../twitter/distributedlog/zk/DefaultZKOp.java  |   55 -
 .../distributedlog/zk/LimitedPermitManager.java |  195 -
 .../com/twitter/distributedlog/zk/ZKOp.java     |   63 -
 .../distributedlog/zk/ZKTransaction.java        |  103 -
 .../distributedlog/zk/ZKVersionedSetOp.java     |   71 -
 .../distributedlog/zk/ZKWatcherManager.java     |  239 --
 .../distributedlog/AppendOnlyStreamReader.java  |  198 +
 .../distributedlog/AppendOnlyStreamWriter.java  |  107 +
 .../apache/distributedlog/AsyncLogReader.java   |   69 +
 .../apache/distributedlog/AsyncLogWriter.java   |   70 +
 .../distributedlog/AsyncNotification.java       |   32 +
 .../distributedlog/BKAbstractLogWriter.java     |  555 +++
 .../apache/distributedlog/BKAsyncLogReader.java |  751 ++++
 .../apache/distributedlog/BKAsyncLogWriter.java |  559 +++
 .../distributedlog/BKDistributedLogManager.java | 1106 ++++++
 .../BKDistributedLogNamespace.java              |  320 ++
 .../org/apache/distributedlog/BKLogHandler.java |  715 ++++
 .../apache/distributedlog/BKLogReadHandler.java |  431 +++
 .../distributedlog/BKLogSegmentWriter.java      | 1348 +++++++
 .../distributedlog/BKLogWriteHandler.java       | 1325 +++++++
 .../apache/distributedlog/BKSyncLogReader.java  |  276 ++
 .../apache/distributedlog/BKSyncLogWriter.java  |  113 +
 .../apache/distributedlog/BKTransmitPacket.java |   90 +
 .../apache/distributedlog/BookKeeperClient.java |  289 ++
 .../distributedlog/BookKeeperClientBuilder.java |  209 ++
 .../DistributedLogConfiguration.java            | 3528 ++++++++++++++++++
 .../distributedlog/DistributedLogConstants.java |   69 +
 .../distributedlog/DistributedLogManager.java   |  308 ++
 .../java/org/apache/distributedlog/Entry.java   |  403 ++
 .../org/apache/distributedlog/EntryBuffer.java  |   70 +
 .../apache/distributedlog/EntryPosition.java    |   63 +
 .../apache/distributedlog/EnvelopedEntry.java   |  296 ++
 .../distributedlog/EnvelopedEntryReader.java    |  102 +
 .../distributedlog/EnvelopedEntryWriter.java    |  192 +
 .../distributedlog/LedgerReadPosition.java      |  171 +
 .../apache/distributedlog/LocalDLMEmulator.java |  364 ++
 .../org/apache/distributedlog/LogReader.java    |  195 +
 .../distributedlog/LogSegmentMetadata.java      | 1125 ++++++
 .../org/apache/distributedlog/LogWriter.java    |   78 +
 .../distributedlog/MaxLogSegmentSequenceNo.java |   72 +
 .../java/org/apache/distributedlog/MaxTxId.java |   72 +
 .../apache/distributedlog/MetadataAccessor.java |   43 +
 .../distributedlog/ReadAheadEntryReader.java    |  992 +++++
 .../org/apache/distributedlog/ReadUtils.java    |  782 ++++
 .../org/apache/distributedlog/WriteLimiter.java |   62 +
 .../apache/distributedlog/ZooKeeperClient.java  |  402 ++
 .../distributedlog/ZooKeeperClientBuilder.java  |  233 ++
 .../acl/AccessControlManager.java               |   74 +
 .../acl/DefaultAccessControlManager.java        |   55 +
 .../apache/distributedlog/acl/package-info.java |   21 +
 .../admin/DistributedLogAdmin.java              |  921 +++++
 .../distributedlog/admin/package-info.java      |   21 +
 .../distributedlog/auditor/DLAuditor.java       |  630 ++++
 .../bk/DynamicQuorumConfigProvider.java         |   37 +
 .../bk/ImmutableQuorumConfigProvider.java       |   35 +
 .../distributedlog/bk/LedgerAllocator.java      |   32 +
 .../bk/LedgerAllocatorDelegator.java            |   83 +
 .../distributedlog/bk/LedgerAllocatorPool.java  |  458 +++
 .../distributedlog/bk/LedgerAllocatorUtils.java |   54 +
 .../apache/distributedlog/bk/QuorumConfig.java  |   92 +
 .../distributedlog/bk/QuorumConfigProvider.java |   32 +
 .../bk/SimpleLedgerAllocator.java               |  536 +++
 .../apache/distributedlog/bk/package-info.java  |   24 +
 .../callback/LogSegmentListener.java            |   42 +
 .../callback/LogSegmentNamesListener.java       |   42 +
 .../callback/NamespaceListener.java             |   34 +
 .../callback/ReadAheadCallback.java             |   25 +
 .../distributedlog/callback/package-info.java   |   21 +
 .../config/ConcurrentBaseConfiguration.java     |   76 +
 .../config/ConcurrentConstConfiguration.java    |   31 +
 .../config/ConfigurationListener.java           |   32 +
 .../config/ConfigurationSubscription.java       |  186 +
 .../config/DynamicConfigurationFactory.java     |   91 +
 .../DynamicDistributedLogConfiguration.java     |  356 ++
 .../config/FileConfigurationBuilder.java        |   28 +
 .../config/PropertiesConfigurationBuilder.java  |   40 +
 .../distributedlog/config/package-info.java     |   21 +
 .../distributedlog/exceptions/ZKException.java  |   54 +
 .../feature/AbstractFeatureProvider.java        |  103 +
 .../feature/ConfigurationFeatureProvider.java   |   76 +
 .../distributedlog/feature/CoreFeatureKeys.java |   29 +
 .../feature/DefaultFeatureProvider.java         |   47 +
 .../DynamicConfigurationFeatureProvider.java    |  132 +
 .../distributedlog/feature/package-info.java    |   21 +
 .../function/CloseAsyncCloseableFunction.java   |   51 +
 .../function/DefaultValueMapFunction.java       |   41 +
 .../function/GetLastTxIdFunction.java           |   43 +
 .../function/GetVersionedValueFunction.java     |   39 +
 .../distributedlog/function/VoidFunctions.java  |   34 +
 .../distributedlog/function/package-info.java   |   21 +
 .../distributedlog/impl/BKNamespaceDriver.java  |  631 ++++
 .../distributedlog/impl/ZKLogMetadataStore.java |  124 +
 .../impl/ZKLogSegmentFilters.java               |   89 +
 .../impl/ZKLogSegmentMetadataStore.java         |  503 +++
 .../distributedlog/impl/ZKMetadataAccessor.java |  264 ++
 .../distributedlog/impl/ZKNamespaceWatcher.java |  133 +
 .../impl/acl/ZKAccessControl.java               |  232 ++
 .../impl/acl/ZKAccessControlManager.java        |  374 ++
 .../federated/FederatedZKLogMetadataStore.java  |  760 ++++
 .../impl/logsegment/BKLogSegmentAllocator.java  |   85 +
 .../logsegment/BKLogSegmentEntryReader.java     |  837 +++++
 .../impl/logsegment/BKLogSegmentEntryStore.java |  286 ++
 .../logsegment/BKLogSegmentEntryWriter.java     |   61 +
 .../BKLogSegmentRandomAccessEntryReader.java    |  119 +
 .../distributedlog/impl/logsegment/BKUtils.java |   72 +
 .../impl/metadata/BKDLConfig.java               |  400 ++
 .../impl/metadata/ZKLogStreamMetadataStore.java |  633 ++++
 .../impl/metadata/ZkMetadataResolver.java       |   72 +
 .../distributedlog/impl/package-info.java       |   21 +
 .../subscription/ZKSubscriptionStateStore.java  |  121 +
 .../impl/subscription/ZKSubscriptionsStore.java |  164 +
 .../injector/AsyncFailureInjector.java          |  131 +
 .../injector/AsyncRandomFailureInjector.java    |  186 +
 .../injector/FailureInjector.java               |   37 +
 .../injector/RandomDelayFailureInjector.java    |   60 +
 .../distributedlog/injector/package-info.java   |   21 +
 .../org/apache/distributedlog/io/Abortable.java |   41 +
 .../apache/distributedlog/io/Abortables.java    |  183 +
 .../distributedlog/io/AsyncAbortable.java       |   57 +
 .../distributedlog/io/AsyncCloseable.java       |   60 +
 .../distributedlog/io/AsyncDeleteable.java      |   34 +
 .../apache/distributedlog/io/package-info.java  |   21 +
 .../limiter/ChainedRequestLimiter.java          |   76 +
 .../limiter/ComposableRequestLimiter.java       |   73 +
 .../limiter/GuavaRateLimiter.java               |   58 +
 .../distributedlog/limiter/RateLimiter.java     |   49 +
 .../distributedlog/limiter/RequestLimiter.java  |   24 +
 .../distributedlog/limiter/package-info.java    |   21 +
 .../distributedlog/lock/DistributedLock.java    |   54 +
 .../lock/DistributedLockContext.java            |   43 +
 .../lock/EpochChangedException.java             |   33 +
 .../apache/distributedlog/lock/LockAction.java  |   36 +
 .../lock/LockClosedException.java               |   38 +
 .../distributedlog/lock/LockListener.java       |   28 +
 .../lock/LockSessionExpiredException.java       |   34 +
 .../lock/LockStateChangedException.java         |   36 +
 .../lock/LockTimeoutException.java              |   34 +
 .../apache/distributedlog/lock/LockWaiter.java  |   95 +
 .../distributedlog/lock/NopDistributedLock.java |   51 +
 .../apache/distributedlog/lock/SessionLock.java |  126 +
 .../distributedlog/lock/SessionLockFactory.java |   38 +
 .../distributedlog/lock/ZKDistributedLock.java  |  537 +++
 .../distributedlog/lock/ZKSessionLock.java      | 1363 +++++++
 .../lock/ZKSessionLockFactory.java              |  133 +
 .../distributedlog/lock/package-info.java       |   21 +
 .../logsegment/LogSegmentEntryReader.java       |  113 +
 .../logsegment/LogSegmentEntryStore.java        |   73 +
 .../logsegment/LogSegmentEntryWriter.java       |   72 +
 .../logsegment/LogSegmentFilter.java            |   42 +
 .../logsegment/LogSegmentMetadataCache.java     |   98 +
 .../logsegment/LogSegmentMetadataStore.java     |  163 +
 .../LogSegmentRandomAccessEntryReader.java      |   47 +
 .../logsegment/LogSegmentWriter.java            |   87 +
 .../logsegment/PerStreamLogSegmentCache.java    |  243 ++
 .../logsegment/RollingPolicy.java               |   33 +
 .../logsegment/SizeBasedRollingPolicy.java      |   34 +
 .../logsegment/TimeBasedRollingPolicy.java      |   46 +
 .../distributedlog/logsegment/package-info.java |   21 +
 .../distributedlog/metadata/DLConfig.java       |   39 +
 .../distributedlog/metadata/DLMetadata.java     |  227 ++
 .../DryrunLogSegmentMetadataStoreUpdater.java   |   51 +
 .../distributedlog/metadata/LogMetadata.java    |  175 +
 .../metadata/LogMetadataForReader.java          |  103 +
 .../metadata/LogMetadataForWriter.java          |   64 +
 .../metadata/LogMetadataStore.java              |   66 +
 .../LogSegmentMetadataStoreUpdater.java         |  184 +
 .../metadata/LogStreamMetadataStore.java        |  114 +
 .../metadata/MetadataResolver.java              |   51 +
 .../metadata/MetadataUpdater.java               |  120 +
 .../distributedlog/metadata/package-info.java   |   21 +
 .../namespace/DistributedLogNamespace.java      |  190 +
 .../DistributedLogNamespaceBuilder.java         |  278 ++
 .../namespace/NamespaceDriver.java              |  138 +
 .../namespace/NamespaceDriverManager.java       |  180 +
 .../namespace/NamespaceWatcher.java             |   61 +
 .../distributedlog/namespace/package-info.java  |   21 +
 .../apache/distributedlog/net/DNSResolver.java  |  113 +
 .../distributedlog/net/DNSResolverForRacks.java |   66 +
 .../distributedlog/net/DNSResolverForRows.java  |   72 +
 .../org/apache/distributedlog/net/NetUtils.java |   74 +
 .../apache/distributedlog/net/package-info.java |   33 +
 .../org/apache/distributedlog/package-info.java |   21 +
 .../distributedlog/rate/MovingAverageRate.java  |   24 +
 .../rate/MovingAverageRateFactory.java          |   65 +
 .../rate/SampledMovingAverageRate.java          |   58 +
 .../distributedlog/readahead/package-info.java  |   21 +
 .../selector/FirstDLSNNotLessThanSelector.java  |   46 +
 .../selector/FirstRecordSelector.java           |   46 +
 .../selector/FirstTxIdNotLessThanSelector.java  |   51 +
 .../selector/LastRecordSelector.java            |   38 +
 .../selector/LogRecordSelector.java             |   40 +
 .../stats/BKExceptionStatsLogger.java           |  109 +
 .../stats/BroadCastStatsLogger.java             |  194 +
 .../distributedlog/stats/OpStatsListener.java   |   51 +
 .../subscription/SubscriptionStateStore.java    |   42 +
 .../subscription/SubscriptionsStore.java        |   69 +
 .../tools/DistributedLogTool.java               | 2873 ++++++++++++++
 .../org/apache/distributedlog/tools/Tool.java   |  243 ++
 .../distributedlog/tools/package-info.java      |   21 +
 .../apache/distributedlog/util/Allocator.java   |  102 +
 .../distributedlog/util/CommandLineUtils.java   |   56 +
 .../apache/distributedlog/util/ConfUtils.java   |   65 +
 .../org/apache/distributedlog/util/DLUtils.java |  321 ++
 .../distributedlog/util/FailpointUtils.java     |  134 +
 .../apache/distributedlog/util/FutureUtils.java |  534 +++
 .../util/MonitoredFuturePool.java               |  131 +
 .../MonitoredScheduledThreadPoolExecutor.java   |  257 ++
 .../distributedlog/util/OrderedScheduler.java   |  490 +++
 .../distributedlog/util/PermitLimiter.java      |   57 +
 .../distributedlog/util/PermitManager.java      |   93 +
 .../distributedlog/util/RetryPolicyUtils.java   |   45 +
 .../util/SafeQueueingFuturePool.java            |  115 +
 .../distributedlog/util/SchedulerUtils.java     |   56 +
 .../apache/distributedlog/util/Sequencer.java   |   31 +
 .../util/SimplePermitLimiter.java               |  117 +
 .../org/apache/distributedlog/util/Sizable.java |   31 +
 .../distributedlog/util/TimeSequencer.java      |   39 +
 .../apache/distributedlog/util/Transaction.java |   97 +
 .../org/apache/distributedlog/util/Utils.java   |  607 +++
 .../distributedlog/util/package-info.java       |   21 +
 .../apache/distributedlog/zk/DefaultZKOp.java   |   55 +
 .../distributedlog/zk/LimitedPermitManager.java |  195 +
 .../java/org/apache/distributedlog/zk/ZKOp.java |   63 +
 .../apache/distributedlog/zk/ZKTransaction.java |  103 +
 .../distributedlog/zk/ZKVersionedSetOp.java     |   71 +
 .../distributedlog/zk/ZKWatcherManager.java     |  239 ++
 .../src/main/resources/findbugsExclude.xml      |    8 +-
 .../src/main/thrift/metadata.thrift             |    2 +-
 .../com/twitter/distributedlog/DLMTestUtil.java |  489 ---
 .../NonBlockingReadsTestUtil.java               |  145 -
 .../TestAppendOnlyStreamReader.java             |  207 -
 .../TestAppendOnlyStreamWriter.java             |  337 --
 .../distributedlog/TestAsyncBulkWrite.java      |  351 --
 .../distributedlog/TestAsyncReaderLock.java     |  607 ---
 .../distributedlog/TestAsyncReaderWriter.java   | 2206 -----------
 .../TestBKDistributedLogManager.java            | 1201 ------
 .../TestBKDistributedLogNamespace.java          |  440 ---
 .../distributedlog/TestBKLogReadHandler.java    |  398 --
 .../distributedlog/TestBKLogSegmentWriter.java  |  790 ----
 .../distributedlog/TestBKLogWriteHandler.java   |   90 -
 .../distributedlog/TestBKSyncLogReader.java     |  306 --
 .../twitter/distributedlog/TestDLMTestUtil.java |   62 -
 .../distributedlog/TestDistributedLogBase.java  |  244 --
 .../TestDistributedLogConfiguration.java        |  132 -
 .../com/twitter/distributedlog/TestEntry.java   |  345 --
 .../distributedlog/TestEntryPosition.java       |   59 -
 .../distributedlog/TestEnvelopedEntry.java      |   81 -
 .../distributedlog/TestInterleavedReaders.java  |  338 --
 .../distributedlog/TestLogSegmentCreation.java  |  106 -
 .../distributedlog/TestLogSegmentMetadata.java  |  159 -
 .../distributedlog/TestLogSegmentsZK.java       |  245 --
 .../distributedlog/TestNonBlockingReads.java    |  348 --
 .../TestNonBlockingReadsMultiReader.java        |  168 -
 .../TestReadAheadEntryReader.java               |  463 ---
 .../twitter/distributedlog/TestReadUtils.java   |  344 --
 .../com/twitter/distributedlog/TestReader.java  |  206 -
 .../distributedlog/TestRollLogSegments.java     |  429 ---
 .../twitter/distributedlog/TestSequenceID.java  |  254 --
 .../twitter/distributedlog/TestTruncate.java    |  341 --
 .../distributedlog/TestWriteLimiter.java        |  205 -
 .../distributedlog/TestZooKeeperClient.java     |  449 ---
 .../TestZooKeeperClientBuilder.java             |   57 -
 .../distributedlog/ZooKeeperClientUtils.java    |   95 -
 .../ZooKeeperClusterTestCase.java               |   53 -
 .../distributedlog/acl/TestZKAccessControl.java |  154 -
 .../acl/TestZKAccessControlManager.java         |  178 -
 .../twitter/distributedlog/admin/TestDLCK.java  |  164 -
 .../admin/TestDistributedLogAdmin.java          |  194 -
 .../distributedlog/bk/TestLedgerAllocator.java  |  389 --
 .../bk/TestLedgerAllocatorPool.java             |  311 --
 .../distributedlog/config/PropertiesWriter.java |   67 -
 .../config/TestConcurrentBaseConfiguration.java |   46 -
 .../config/TestConfigurationSubscription.java   |  171 -
 .../config/TestDynamicConfigurationFactory.java |  101 -
 .../TestDynamicDistributedLogConfiguration.java |  261 --
 .../TestConfigurationFeatureProvider.java       |   65 -
 ...TestDynamicConfigurationFeatureProvider.java |  183 -
 .../impl/TestZKLogMetadataStore.java            |  114 -
 .../impl/TestZKLogSegmentFilters.java           |   74 -
 .../impl/TestZKLogSegmentMetadataStore.java     |  831 -----
 .../impl/TestZKNamespaceWatcher.java            |  185 -
 .../TestFederatedZKLogMetadataStore.java        |  446 ---
 .../logsegment/TestBKLogSegmentEntryReader.java |  561 ---
 .../metadata/TestZKLogStreamMetadataStore.java  |  327 --
 .../TestZKLogStreamMetadataStoreUtils.java      |  208 --
 .../impl/metadata/TestZkMetadataResolver.java   |  203 -
 .../limiter/TestRequestLimiter.java             |   60 -
 .../lock/TestDistributedLock.java               |  835 -----
 .../distributedlog/lock/TestZKSessionLock.java  | 1224 ------
 .../TestPerStreamLogSegmentCache.java           |  186 -
 .../logsegment/TestRollingPolicy.java           |   63 -
 .../distributedlog/metadata/TestDLMetadata.java |  195 -
 .../metadata/TestLogMetadata.java               |   59 -
 .../TestLogSegmentMetadataStoreUpdater.java     |  284 --
 .../TestDistributedLogNamespaceBuilder.java     |  124 -
 .../distributedlog/net/TestDNSResolver.java     |   96 -
 .../distributedlog/net/TestNetUtils.java        |   82 -
 .../rate/TestMovingAverageRate.java             |   99 -
 .../selector/TestLogRecordSelectors.java        |  128 -
 .../tools/TestDistributedLogTool.java           |  231 --
 .../distributedlog/util/TestConfUtils.java      |   53 -
 .../distributedlog/util/TestDLUtils.java        |  273 --
 .../distributedlog/util/TestFutureUtils.java    |   71 -
 .../distributedlog/util/TestPermitManager.java  |   92 -
 .../util/TestSafeQueueingFuturePool.java        |  205 -
 .../distributedlog/util/TestTimeSequencer.java  |   42 -
 .../twitter/distributedlog/util/TestUtils.java  |  125 -
 .../distributedlog/zk/TestZKTransaction.java    |   97 -
 .../distributedlog/zk/TestZKVersionedSetOp.java |   86 -
 .../distributedlog/zk/TestZKWatcherManager.java |   80 -
 .../org/apache/distributedlog/DLMTestUtil.java  |  489 +++
 .../NonBlockingReadsTestUtil.java               |  145 +
 .../TestAppendOnlyStreamReader.java             |  207 +
 .../TestAppendOnlyStreamWriter.java             |  337 ++
 .../distributedlog/TestAsyncBulkWrite.java      |  351 ++
 .../distributedlog/TestAsyncReaderLock.java     |  607 +++
 .../distributedlog/TestAsyncReaderWriter.java   | 2206 +++++++++++
 .../TestBKDistributedLogManager.java            | 1201 ++++++
 .../TestBKDistributedLogNamespace.java          |  440 +++
 .../distributedlog/TestBKLogReadHandler.java    |  398 ++
 .../distributedlog/TestBKLogSegmentWriter.java  |  790 ++++
 .../distributedlog/TestBKLogWriteHandler.java   |   90 +
 .../distributedlog/TestBKSyncLogReader.java     |  306 ++
 .../apache/distributedlog/TestDLMTestUtil.java  |   62 +
 .../distributedlog/TestDistributedLogBase.java  |  244 ++
 .../TestDistributedLogConfiguration.java        |  132 +
 .../org/apache/distributedlog/TestEntry.java    |  345 ++
 .../distributedlog/TestEntryPosition.java       |   59 +
 .../distributedlog/TestEnvelopedEntry.java      |   81 +
 .../distributedlog/TestInterleavedReaders.java  |  338 ++
 .../distributedlog/TestLogSegmentCreation.java  |  106 +
 .../distributedlog/TestLogSegmentMetadata.java  |  159 +
 .../distributedlog/TestLogSegmentsZK.java       |  245 ++
 .../distributedlog/TestNonBlockingReads.java    |  348 ++
 .../TestNonBlockingReadsMultiReader.java        |  168 +
 .../TestReadAheadEntryReader.java               |  463 +++
 .../apache/distributedlog/TestReadUtils.java    |  344 ++
 .../org/apache/distributedlog/TestReader.java   |  206 +
 .../distributedlog/TestRollLogSegments.java     |  429 +++
 .../apache/distributedlog/TestSequenceID.java   |  254 ++
 .../org/apache/distributedlog/TestTruncate.java |  341 ++
 .../apache/distributedlog/TestWriteLimiter.java |  205 +
 .../distributedlog/TestZooKeeperClient.java     |  449 +++
 .../TestZooKeeperClientBuilder.java             |   57 +
 .../distributedlog/ZooKeeperClientUtils.java    |   95 +
 .../ZooKeeperClusterTestCase.java               |   53 +
 .../distributedlog/acl/TestZKAccessControl.java |  154 +
 .../acl/TestZKAccessControlManager.java         |  178 +
 .../apache/distributedlog/admin/TestDLCK.java   |  164 +
 .../admin/TestDistributedLogAdmin.java          |  194 +
 .../distributedlog/bk/TestLedgerAllocator.java  |  389 ++
 .../bk/TestLedgerAllocatorPool.java             |  311 ++
 .../distributedlog/config/PropertiesWriter.java |   67 +
 .../config/TestConcurrentBaseConfiguration.java |   46 +
 .../config/TestConfigurationSubscription.java   |  171 +
 .../config/TestDynamicConfigurationFactory.java |  101 +
 .../TestDynamicDistributedLogConfiguration.java |  261 ++
 .../TestConfigurationFeatureProvider.java       |   65 +
 ...TestDynamicConfigurationFeatureProvider.java |  183 +
 .../impl/TestZKLogMetadataStore.java            |  114 +
 .../impl/TestZKLogSegmentFilters.java           |   74 +
 .../impl/TestZKLogSegmentMetadataStore.java     |  831 +++++
 .../impl/TestZKNamespaceWatcher.java            |  185 +
 .../TestFederatedZKLogMetadataStore.java        |  446 +++
 .../logsegment/TestBKLogSegmentEntryReader.java |  561 +++
 .../metadata/TestZKLogStreamMetadataStore.java  |  327 ++
 .../TestZKLogStreamMetadataStoreUtils.java      |  208 ++
 .../impl/metadata/TestZkMetadataResolver.java   |  203 +
 .../limiter/TestRequestLimiter.java             |   60 +
 .../lock/TestDistributedLock.java               |  835 +++++
 .../distributedlog/lock/TestZKSessionLock.java  | 1224 ++++++
 .../TestPerStreamLogSegmentCache.java           |  186 +
 .../logsegment/TestRollingPolicy.java           |   63 +
 .../distributedlog/metadata/TestDLMetadata.java |  195 +
 .../metadata/TestLogMetadata.java               |   59 +
 .../TestLogSegmentMetadataStoreUpdater.java     |  284 ++
 .../TestDistributedLogNamespaceBuilder.java     |  124 +
 .../distributedlog/net/TestDNSResolver.java     |   96 +
 .../apache/distributedlog/net/TestNetUtils.java |   82 +
 .../rate/TestMovingAverageRate.java             |   99 +
 .../selector/TestLogRecordSelectors.java        |  128 +
 .../tools/TestDistributedLogTool.java           |  231 ++
 .../distributedlog/util/TestConfUtils.java      |   53 +
 .../apache/distributedlog/util/TestDLUtils.java |  273 ++
 .../distributedlog/util/TestFutureUtils.java    |   71 +
 .../distributedlog/util/TestPermitManager.java  |   92 +
 .../util/TestSafeQueueingFuturePool.java        |  205 +
 .../distributedlog/util/TestTimeSequencer.java  |   42 +
 .../apache/distributedlog/util/TestUtils.java   |  125 +
 .../distributedlog/zk/TestZKTransaction.java    |   97 +
 .../distributedlog/zk/TestZKVersionedSetOp.java |   86 +
 .../distributedlog/zk/TestZKWatcherManager.java |   80 +
 .../java/com/twitter/distributedlog/DLSN.java   |  266 --
 .../EnvelopedRecordSetReader.java               |  118 -
 .../EnvelopedRecordSetWriter.java               |  197 -
 .../com/twitter/distributedlog/LogRecord.java   |  606 ---
 .../twitter/distributedlog/LogRecordSet.java    |  155 -
 .../distributedlog/LogRecordSetBuffer.java      |   65 -
 .../distributedlog/LogRecordWithDLSN.java       |  107 -
 .../twitter/distributedlog/RecordStream.java    |   42 -
 .../annotations/DistributedLogAnnotations.java  |   35 -
 .../annotations/package-info.java               |   21 -
 .../exceptions/AlreadyClosedException.java      |   34 -
 .../AlreadyTruncatedTransactionException.java   |   32 -
 .../exceptions/BKTransmitException.java         |   42 -
 .../exceptions/ChecksumFailedException.java     |   32 -
 .../exceptions/DLClientClosedException.java     |   36 -
 .../distributedlog/exceptions/DLException.java  |   81 -
 .../exceptions/DLIllegalStateException.java     |   36 -
 .../exceptions/DLInterruptedException.java      |   36 -
 .../exceptions/EndOfLogSegmentException.java    |   32 -
 .../exceptions/EndOfStreamException.java        |   32 -
 .../exceptions/FlushException.java              |   51 -
 .../exceptions/IdleReaderException.java         |   34 -
 .../exceptions/InternalServerException.java     |   40 -
 .../InvalidEnvelopedEntryException.java         |   32 -
 .../exceptions/InvalidStreamNameException.java  |   36 -
 .../exceptions/LockCancelledException.java      |   31 -
 .../exceptions/LockingException.java            |   44 -
 .../exceptions/LogEmptyException.java           |   32 -
 .../exceptions/LogExistsException.java          |   31 -
 .../exceptions/LogNotFoundException.java        |   32 -
 .../exceptions/LogReadException.java            |   33 -
 .../exceptions/LogRecordTooLongException.java   |   34 -
 .../LogSegmentIsTruncatedException.java         |   33 -
 .../exceptions/LogSegmentNotFoundException.java |   32 -
 .../exceptions/MetadataException.java           |   36 -
 .../exceptions/NotYetImplementedException.java  |   32 -
 .../exceptions/OverCapacityException.java       |   39 -
 .../OwnershipAcquireFailedException.java        |   40 -
 .../exceptions/ReadCancelledException.java      |   33 -
 .../exceptions/RegionUnavailableException.java  |   34 -
 .../exceptions/RequestDeniedException.java      |   33 -
 .../exceptions/RetryableReadException.java      |   36 -
 .../exceptions/ServiceUnavailableException.java |   32 -
 .../exceptions/StreamNotReadyException.java     |   32 -
 .../exceptions/StreamUnavailableException.java  |   32 -
 .../exceptions/TooManyStreamsException.java     |   32 -
 .../TransactionIdOutOfOrderException.java       |   47 -
 .../exceptions/UnexpectedException.java         |   40 -
 .../UnsupportedMetadataVersionException.java    |   32 -
 .../exceptions/WriteCancelledException.java     |   45 -
 .../exceptions/WriteException.java              |   33 -
 .../distributedlog/exceptions/package-info.java |   21 -
 .../com/twitter/distributedlog/io/Buffer.java   |   33 -
 .../distributedlog/io/CompressionCodec.java     |   80 -
 .../distributedlog/io/CompressionUtils.java     |   58 -
 .../io/IdentityCompressionCodec.java            |   50 -
 .../distributedlog/io/LZ4CompressionCodec.java  |  101 -
 .../distributedlog/io/TransmitListener.java     |   56 -
 .../twitter/distributedlog/io/package-info.java |   21 -
 .../twitter/distributedlog/package-info.java    |   21 -
 .../distributedlog/util/BitMaskUtils.java       |   57 -
 .../distributedlog/util/ProtocolUtils.java      |   79 -
 .../distributedlog/util/package-info.java       |   21 -
 .../java/org/apache/distributedlog/DLSN.java    |  266 ++
 .../EnvelopedRecordSetReader.java               |  118 +
 .../EnvelopedRecordSetWriter.java               |  197 +
 .../org/apache/distributedlog/LogRecord.java    |  606 +++
 .../org/apache/distributedlog/LogRecordSet.java |  155 +
 .../distributedlog/LogRecordSetBuffer.java      |   65 +
 .../distributedlog/LogRecordWithDLSN.java       |  107 +
 .../org/apache/distributedlog/RecordStream.java |   42 +
 .../annotations/DistributedLogAnnotations.java  |   35 +
 .../annotations/package-info.java               |   21 +
 .../exceptions/AlreadyClosedException.java      |   34 +
 .../AlreadyTruncatedTransactionException.java   |   32 +
 .../exceptions/BKTransmitException.java         |   42 +
 .../exceptions/ChecksumFailedException.java     |   32 +
 .../exceptions/DLClientClosedException.java     |   36 +
 .../distributedlog/exceptions/DLException.java  |   81 +
 .../exceptions/DLIllegalStateException.java     |   36 +
 .../exceptions/DLInterruptedException.java      |   36 +
 .../exceptions/EndOfLogSegmentException.java    |   32 +
 .../exceptions/EndOfStreamException.java        |   32 +
 .../exceptions/FlushException.java              |   51 +
 .../exceptions/IdleReaderException.java         |   34 +
 .../exceptions/InternalServerException.java     |   40 +
 .../InvalidEnvelopedEntryException.java         |   32 +
 .../exceptions/InvalidStreamNameException.java  |   36 +
 .../exceptions/LockCancelledException.java      |   31 +
 .../exceptions/LockingException.java            |   44 +
 .../exceptions/LogEmptyException.java           |   32 +
 .../exceptions/LogExistsException.java          |   31 +
 .../exceptions/LogNotFoundException.java        |   32 +
 .../exceptions/LogReadException.java            |   33 +
 .../exceptions/LogRecordTooLongException.java   |   34 +
 .../LogSegmentIsTruncatedException.java         |   33 +
 .../exceptions/LogSegmentNotFoundException.java |   32 +
 .../exceptions/MetadataException.java           |   36 +
 .../exceptions/NotYetImplementedException.java  |   32 +
 .../exceptions/OverCapacityException.java       |   39 +
 .../OwnershipAcquireFailedException.java        |   40 +
 .../exceptions/ReadCancelledException.java      |   33 +
 .../exceptions/RegionUnavailableException.java  |   34 +
 .../exceptions/RequestDeniedException.java      |   33 +
 .../exceptions/RetryableReadException.java      |   36 +
 .../exceptions/ServiceUnavailableException.java |   32 +
 .../exceptions/StreamNotReadyException.java     |   32 +
 .../exceptions/StreamUnavailableException.java  |   32 +
 .../exceptions/TooManyStreamsException.java     |   32 +
 .../TransactionIdOutOfOrderException.java       |   47 +
 .../exceptions/UnexpectedException.java         |   40 +
 .../UnsupportedMetadataVersionException.java    |   32 +
 .../exceptions/WriteCancelledException.java     |   45 +
 .../exceptions/WriteException.java              |   33 +
 .../distributedlog/exceptions/package-info.java |   21 +
 .../org/apache/distributedlog/io/Buffer.java    |   33 +
 .../distributedlog/io/CompressionCodec.java     |   80 +
 .../distributedlog/io/CompressionUtils.java     |   58 +
 .../io/IdentityCompressionCodec.java            |   50 +
 .../distributedlog/io/LZ4CompressionCodec.java  |  101 +
 .../distributedlog/io/TransmitListener.java     |   56 +
 .../apache/distributedlog/io/package-info.java  |   21 +
 .../org/apache/distributedlog/package-info.java |   21 +
 .../distributedlog/util/BitMaskUtils.java       |   57 +
 .../distributedlog/util/ProtocolUtils.java      |   79 +
 .../distributedlog/util/package-info.java       |   21 +
 .../src/main/resources/findbugsExclude.xml      |    8 +-
 .../src/main/thrift/service.thrift              |    2 +-
 .../com/twitter/distributedlog/TestDLSN.java    |   64 -
 .../distributedlog/TestLogRecordSet.java        |  178 -
 .../TestTimedOutTestsListener.java              |  183 -
 .../distributedlog/TimedOutTestsListener.java   |  168 -
 .../org/apache/distributedlog/TestDLSN.java     |   64 +
 .../apache/distributedlog/TestLogRecordSet.java |  178 +
 .../TestTimedOutTestsListener.java              |  183 +
 .../distributedlog/TimedOutTestsListener.java   |  168 +
 distributedlog-service/bin/dlog-daemon.sh       |    2 +-
 distributedlog-service/bin/dlog-start.sh        |    2 +-
 distributedlog-service/pom.xml                  |    2 +-
 .../distributedlog/service/ClientUtils.java     |   33 -
 .../service/DistributedLogCluster.java          |  352 --
 .../service/DistributedLogServer.java           |  460 ---
 .../service/DistributedLogServerApp.java        |  187 -
 .../service/DistributedLogServiceImpl.java      |  794 ----
 .../service/FatalErrorHandler.java              |   30 -
 .../distributedlog/service/MonitorService.java  |  469 ---
 .../service/MonitorServiceApp.java              |  133 -
 .../distributedlog/service/ResponseUtils.java   |   86 -
 .../service/ServerFeatureKeys.java              |   29 -
 .../distributedlog/service/StatsFilter.java     |   60 -
 .../service/announcer/Announcer.java            |   41 -
 .../service/announcer/NOPAnnouncer.java         |   40 -
 .../service/announcer/ServerSetAnnouncer.java   |  111 -
 .../service/announcer/package-info.java         |   21 -
 .../service/balancer/Balancer.java              |   68 -
 .../service/balancer/BalancerTool.java          |  327 --
 .../service/balancer/BalancerUtils.java         |   74 -
 .../service/balancer/ClusterBalancer.java       |  378 --
 .../balancer/CountBasedStreamChooser.java       |  109 -
 .../service/balancer/LimitedStreamChooser.java  |   57 -
 .../service/balancer/SimpleBalancer.java        |  246 --
 .../service/balancer/StreamChooser.java         |   30 -
 .../service/balancer/StreamMover.java           |   34 -
 .../service/balancer/StreamMoverImpl.java       |   94 -
 .../service/balancer/package-info.java          |   21 -
 .../config/DefaultStreamConfigProvider.java     |   73 -
 .../config/NullStreamConfigProvider.java        |   40 -
 .../service/config/ServerConfiguration.java     |  443 ---
 .../config/ServiceStreamConfigProvider.java     |   88 -
 .../service/config/StreamConfigProvider.java    |   34 -
 .../service/config/package-info.java            |   21 -
 .../distributedlog/service/package-info.java    |   21 -
 .../service/placement/EqualLoadAppraiser.java   |   39 -
 .../placement/LeastLoadPlacementPolicy.java     |  200 -
 .../service/placement/LoadAppraiser.java        |   39 -
 .../service/placement/PlacementPolicy.java      |  148 -
 .../placement/PlacementStateManager.java        |   79 -
 .../service/placement/ServerLoad.java           |  158 -
 .../service/placement/StreamLoad.java           |  115 -
 .../placement/ZKPlacementStateManager.java      |  173 -
 .../service/placement/package-info.java         |   21 -
 .../service/stream/AbstractStreamOp.java        |  175 -
 .../service/stream/AbstractWriteOp.java         |   60 -
 .../service/stream/BulkWriteOp.java             |  253 --
 .../distributedlog/service/stream/DeleteOp.java |   76 -
 .../service/stream/HeartbeatOp.java             |  101 -
 .../service/stream/ReleaseOp.java               |   76 -
 .../distributedlog/service/stream/Stream.java   |   93 -
 .../service/stream/StreamFactory.java           |   38 -
 .../service/stream/StreamFactoryImpl.java       |   95 -
 .../service/stream/StreamImpl.java              |  925 -----
 .../service/stream/StreamManager.java           |  142 -
 .../service/stream/StreamManagerImpl.java       |  413 --
 .../distributedlog/service/stream/StreamOp.java |   75 -
 .../service/stream/StreamOpStats.java           |  104 -
 .../service/stream/TruncateOp.java              |   91 -
 .../distributedlog/service/stream/WriteOp.java  |  173 -
 .../service/stream/WriteOpWithPayload.java      |   27 -
 .../service/stream/admin/AdminOp.java           |   40 -
 .../service/stream/admin/CreateOp.java          |   57 -
 .../service/stream/admin/StreamAdminOp.java     |  100 -
 .../service/stream/admin/package-info.java      |   21 -
 .../stream/limiter/DynamicRequestLimiter.java   |   94 -
 .../stream/limiter/RequestLimiterBuilder.java   |  116 -
 .../stream/limiter/ServiceRequestLimiter.java   |  103 -
 .../stream/limiter/StreamAcquireLimiter.java    |   56 -
 .../stream/limiter/StreamRequestLimiter.java    |   87 -
 .../service/stream/limiter/package-info.java    |   21 -
 .../service/stream/package-info.java            |   21 -
 .../CacheableStreamPartitionConverter.java      |   58 -
 .../DelimiterStreamPartitionConverter.java      |   50 -
 .../IdentityStreamPartitionConverter.java       |   28 -
 .../service/streamset/Partition.java            |   99 -
 .../service/streamset/PartitionMap.java         |   58 -
 .../streamset/StreamPartitionConverter.java     |   35 -
 .../service/streamset/package-info.java         |   21 -
 .../distributedlog/service/tools/ProxyTool.java |  350 --
 .../service/tools/package-info.java             |   21 -
 .../service/utils/ServerUtils.java              |   49 -
 .../service/utils/package-info.java             |   21 -
 .../apache/bookkeeper/stats/package-info.java   |    2 +-
 .../distributedlog/service/ClientUtils.java     |   33 +
 .../service/DistributedLogCluster.java          |  352 ++
 .../service/DistributedLogServer.java           |  460 +++
 .../service/DistributedLogServerApp.java        |  187 +
 .../service/DistributedLogServiceImpl.java      |  794 ++++
 .../service/FatalErrorHandler.java              |   30 +
 .../distributedlog/service/MonitorService.java  |  469 +++
 .../service/MonitorServiceApp.java              |  133 +
 .../distributedlog/service/ResponseUtils.java   |   86 +
 .../service/ServerFeatureKeys.java              |   29 +
 .../distributedlog/service/StatsFilter.java     |   60 +
 .../service/announcer/Announcer.java            |   41 +
 .../service/announcer/NOPAnnouncer.java         |   40 +
 .../service/announcer/ServerSetAnnouncer.java   |  111 +
 .../service/announcer/package-info.java         |   21 +
 .../service/balancer/Balancer.java              |   68 +
 .../service/balancer/BalancerTool.java          |  327 ++
 .../service/balancer/BalancerUtils.java         |   74 +
 .../service/balancer/ClusterBalancer.java       |  378 ++
 .../balancer/CountBasedStreamChooser.java       |  109 +
 .../service/balancer/LimitedStreamChooser.java  |   57 +
 .../service/balancer/SimpleBalancer.java        |  246 ++
 .../service/balancer/StreamChooser.java         |   30 +
 .../service/balancer/StreamMover.java           |   34 +
 .../service/balancer/StreamMoverImpl.java       |   94 +
 .../service/balancer/package-info.java          |   21 +
 .../config/DefaultStreamConfigProvider.java     |   73 +
 .../config/NullStreamConfigProvider.java        |   40 +
 .../service/config/ServerConfiguration.java     |  443 +++
 .../config/ServiceStreamConfigProvider.java     |   88 +
 .../service/config/StreamConfigProvider.java    |   34 +
 .../service/config/package-info.java            |   21 +
 .../distributedlog/service/package-info.java    |   21 +
 .../service/placement/EqualLoadAppraiser.java   |   39 +
 .../placement/LeastLoadPlacementPolicy.java     |  200 +
 .../service/placement/LoadAppraiser.java        |   39 +
 .../service/placement/PlacementPolicy.java      |  148 +
 .../placement/PlacementStateManager.java        |   79 +
 .../service/placement/ServerLoad.java           |  158 +
 .../service/placement/StreamLoad.java           |  115 +
 .../placement/ZKPlacementStateManager.java      |  173 +
 .../service/placement/package-info.java         |   21 +
 .../service/stream/AbstractStreamOp.java        |  175 +
 .../service/stream/AbstractWriteOp.java         |   60 +
 .../service/stream/BulkWriteOp.java             |  253 ++
 .../distributedlog/service/stream/DeleteOp.java |   76 +
 .../service/stream/HeartbeatOp.java             |  101 +
 .../service/stream/ReleaseOp.java               |   76 +
 .../distributedlog/service/stream/Stream.java   |   93 +
 .../service/stream/StreamFactory.java           |   38 +
 .../service/stream/StreamFactoryImpl.java       |   95 +
 .../service/stream/StreamImpl.java              |  925 +++++
 .../service/stream/StreamManager.java           |  142 +
 .../service/stream/StreamManagerImpl.java       |  413 ++
 .../distributedlog/service/stream/StreamOp.java |   75 +
 .../service/stream/StreamOpStats.java           |  104 +
 .../service/stream/TruncateOp.java              |   91 +
 .../distributedlog/service/stream/WriteOp.java  |  173 +
 .../service/stream/WriteOpWithPayload.java      |   27 +
 .../service/stream/admin/AdminOp.java           |   40 +
 .../service/stream/admin/CreateOp.java          |   57 +
 .../service/stream/admin/StreamAdminOp.java     |  100 +
 .../service/stream/admin/package-info.java      |   21 +
 .../stream/limiter/DynamicRequestLimiter.java   |   94 +
 .../stream/limiter/RequestLimiterBuilder.java   |  116 +
 .../stream/limiter/ServiceRequestLimiter.java   |  103 +
 .../stream/limiter/StreamAcquireLimiter.java    |   56 +
 .../stream/limiter/StreamRequestLimiter.java    |   87 +
 .../service/stream/limiter/package-info.java    |   21 +
 .../service/stream/package-info.java            |   21 +
 .../CacheableStreamPartitionConverter.java      |   58 +
 .../DelimiterStreamPartitionConverter.java      |   50 +
 .../IdentityStreamPartitionConverter.java       |   28 +
 .../service/streamset/Partition.java            |   99 +
 .../service/streamset/PartitionMap.java         |   58 +
 .../streamset/StreamPartitionConverter.java     |   35 +
 .../service/streamset/package-info.java         |   21 +
 .../distributedlog/service/tools/ProxyTool.java |  350 ++
 .../service/tools/package-info.java             |   21 +
 .../service/utils/ServerUtils.java              |   49 +
 .../service/utils/package-info.java             |   21 +
 .../src/main/resources/findbugsExclude.xml      |    8 +-
 .../src/main/thrift/metadata.thrift             |    2 +-
 .../client/routing/LocalRoutingService.java     |  146 -
 .../service/DistributedLogServerTestCase.java   |  298 --
 .../service/TestDistributedLogServerBase.java   |  720 ----
 .../TestDistributedLogServerClientRouting.java  |   58 -
 .../TestDistributedLogServerServerRouting.java  |   28 -
 .../service/TestDistributedLogService.java      |  833 -----
 .../service/TestRegionUnavailable.java          |  140 -
 .../distributedlog/service/TestStatsFilter.java |   58 -
 .../service/balancer/TestBalancerUtils.java     |   65 -
 .../service/balancer/TestClusterBalancer.java   |  189 -
 .../balancer/TestCountBasedStreamChooser.java   |  204 -
 .../service/balancer/TestSimpleBalancer.java    |  180 -
 .../service/balancer/TestStreamMover.java       |   86 -
 .../service/config/TestServerConfiguration.java |   68 -
 .../config/TestStreamConfigProvider.java        |  140 -
 .../placement/TestLeastLoadPlacementPolicy.java |  176 -
 .../service/placement/TestServerLoad.java       |   50 -
 .../service/placement/TestStreamLoad.java       |   37 -
 .../placement/TestZKPlacementStateManager.java  |  136 -
 .../service/stream/TestStreamManager.java       |  135 -
 .../service/stream/TestStreamOp.java            |   95 -
 .../limiter/TestServiceRequestLimiter.java      |  301 --
 .../TestDelimiterStreamPartitionConverter.java  |   52 -
 .../TestIdentityStreamPartitionConverter.java   |   43 -
 .../service/streamset/TestPartitionMap.java     |   68 -
 .../service/utils/TestServerUtils.java          |   41 -
 .../client/routing/LocalRoutingService.java     |  146 +
 .../service/DistributedLogServerTestCase.java   |  298 ++
 .../service/TestDistributedLogServerBase.java   |  720 ++++
 .../TestDistributedLogServerClientRouting.java  |   58 +
 .../TestDistributedLogServerServerRouting.java  |   28 +
 .../service/TestDistributedLogService.java      |  833 +++++
 .../service/TestRegionUnavailable.java          |  140 +
 .../distributedlog/service/TestStatsFilter.java |   58 +
 .../service/balancer/TestBalancerUtils.java     |   65 +
 .../service/balancer/TestClusterBalancer.java   |  189 +
 .../balancer/TestCountBasedStreamChooser.java   |  204 +
 .../service/balancer/TestSimpleBalancer.java    |  180 +
 .../service/balancer/TestStreamMover.java       |   86 +
 .../service/config/TestServerConfiguration.java |   68 +
 .../config/TestStreamConfigProvider.java        |  140 +
 .../placement/TestLeastLoadPlacementPolicy.java |  176 +
 .../service/placement/TestServerLoad.java       |   50 +
 .../service/placement/TestStreamLoad.java       |   37 +
 .../placement/TestZKPlacementStateManager.java  |  136 +
 .../service/stream/TestStreamManager.java       |  135 +
 .../service/stream/TestStreamOp.java            |   95 +
 .../limiter/TestServiceRequestLimiter.java      |  301 ++
 .../TestDelimiterStreamPartitionConverter.java  |   52 +
 .../TestIdentityStreamPartitionConverter.java   |   43 +
 .../service/streamset/TestPartitionMap.java     |   68 +
 .../service/utils/TestServerUtils.java          |   41 +
 .../distributedlog-basic/basic-1.md             |   16 +-
 .../distributedlog-basic/basic-2.md             |   10 +-
 .../distributedlog-basic/basic-3.md             |   10 +-
 .../distributedlog-basic/basic-4.md             |   10 +-
 .../distributedlog-basic/basic-5.md             |   10 +-
 .../distributedlog-basic/basic-6.md             |   10 +-
 .../distributedlog-basic/conf/log4j.properties  |    8 +-
 .../distributedlog/basic/AtomicWriter.java      |  107 -
 .../basic/ConsoleProxyMultiWriter.java          |   91 -
 .../basic/ConsoleProxyWriter.java               |   77 -
 .../distributedlog/basic/ConsoleWriter.java     |  101 -
 .../distributedlog/basic/MultiReader.java       |  140 -
 .../distributedlog/basic/RecordGenerator.java   |   90 -
 .../distributedlog/basic/StreamRewinder.java    |  113 -
 .../distributedlog/basic/TailReader.java        |  112 -
 .../distributedlog/basic/AtomicWriter.java      |  107 +
 .../basic/ConsoleProxyMultiWriter.java          |   91 +
 .../basic/ConsoleProxyWriter.java               |   77 +
 .../distributedlog/basic/ConsoleWriter.java     |  101 +
 .../distributedlog/basic/MultiReader.java       |  140 +
 .../distributedlog/basic/RecordGenerator.java   |   90 +
 .../distributedlog/basic/StreamRewinder.java    |  113 +
 .../apache/distributedlog/basic/TailReader.java |  112 +
 .../distributedlog-kafka/conf/log4j.properties  |    8 +-
 .../kafka/DLFutureRecordMetadata.java           |  104 -
 .../kafka/KafkaDistributedLogProducer.java      |  158 -
 .../kafka/DLFutureRecordMetadata.java           |  104 +
 .../kafka/KafkaDistributedLogProducer.java      |  158 +
 .../distributedlog-mapreduce/README.md          |    2 +-
 .../mapreduce/DistributedLogInputFormat.java    |  129 -
 .../mapreduce/LogSegmentReader.java             |  148 -
 .../mapreduce/LogSegmentSplit.java              |   95 -
 .../mapreduce/DistributedLogInputFormat.java    |  129 +
 .../mapreduce/LogSegmentReader.java             |  148 +
 .../mapreduce/LogSegmentSplit.java              |   95 +
 .../conf/log4j.properties                       |    8 +-
 .../distributedlog-messaging/messaging-1.md     |   10 +-
 .../distributedlog-messaging/messaging-2.md     |   10 +-
 .../ConsoleProxyPartitionedMultiWriter.java     |  121 -
 .../messaging/ConsoleProxyRRMultiWriter.java    |   77 -
 .../messaging/IdenticalTransformer.java         |   25 -
 .../messaging/IntPartitioner.java               |   28 -
 .../messaging/PartitionedMultiWriter.java       |   50 -
 .../distributedlog/messaging/Partitioner.java   |   25 -
 .../distributedlog/messaging/RRMultiWriter.java |   94 -
 .../messaging/ReaderWithOffsets.java            |  132 -
 .../messaging/StreamTransformer.java            |  188 -
 .../distributedlog/messaging/Transformer.java   |   34 -
 .../ConsoleProxyPartitionedMultiWriter.java     |  121 +
 .../messaging/ConsoleProxyRRMultiWriter.java    |   77 +
 .../messaging/IdenticalTransformer.java         |   25 +
 .../messaging/IntPartitioner.java               |   28 +
 .../messaging/PartitionedMultiWriter.java       |   50 +
 .../distributedlog/messaging/Partitioner.java   |   25 +
 .../distributedlog/messaging/RRMultiWriter.java |   94 +
 .../messaging/ReaderWithOffsets.java            |  132 +
 .../messaging/StreamTransformer.java            |  188 +
 .../distributedlog/messaging/Transformer.java   |   34 +
 .../src/main/resources/findbugsExclude.xml      |    4 +-
 .../src/main/thrift/messaging.thrift            |    2 +-
 docs/_plugins/jekyll-rst/.gitignore             |    2 +-
 docs/_plugins/jekyll-rst/LICENSE.txt            |    2 +-
 docs/_plugins/jekyll-rst/README.rst             |    2 +-
 docs/_plugins/jekyll-rst/converter.rb           |    2 +-
 docs/_plugins/jekyll-rst/directives.py          |    2 +-
 docs/_plugins/jekyll-rst/transform.py           |    2 +-
 docs/admin_guide/operations.rst                 |    6 +-
 docs/deployment/cluster.rst                     |    6 +-
 .../bootstrap/glyphicons-halflings-regular.svg  |    2 +-
 docs/js/bootstrap.min.js                        |    2 +-
 docs/start/quickstart.rst                       |    4 +-
 docs/tutorials/basic-1.rst                      |   16 +-
 docs/tutorials/basic-2.rst                      |   10 +-
 docs/tutorials/basic-3.rst                      |   10 +-
 docs/tutorials/basic-4.rst                      |   10 +-
 docs/tutorials/basic-5.rst                      |   10 +-
 docs/tutorials/basic-6.rst                      |   10 +-
 docs/tutorials/messaging-1.rst                  |   10 +-
 docs/tutorials/messaging-2.rst                  |   10 +-
 docs/user_guide/implementation/storage.rst      |    2 +-
 pom.xml                                         |    3 +-
 scripts/integration/smoketest.sh                |    4 +-
 .../bootstrap/glyphicons-halflings-regular.svg  |    2 +-
 website/js/bootstrap.min.js                     |    2 +-
 1204 files changed, 100167 insertions(+), 100166 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-distributedlog/blob/b44820b5/distributedlog-benchmark/conf/log4j.properties
----------------------------------------------------------------------
diff --git a/distributedlog-benchmark/conf/log4j.properties b/distributedlog-benchmark/conf/log4j.properties
index 73b4cfa..930db8d 100644
--- a/distributedlog-benchmark/conf/log4j.properties
+++ b/distributedlog-benchmark/conf/log4j.properties
@@ -30,11 +30,11 @@ log4j.logger.org.apache.zookeeper=INFO
 log4j.logger.org.apache.bookkeeper=INFO
 
 # redirect executor output to executors.log since slow op warnings can be quite verbose
-log4j.logger.com.twitter.distributedlog.util.MonitoredFuturePool=INFO, Executors
-log4j.logger.com.twitter.distributedlog.util.MonitoredScheduledThreadPoolExecutor=INFO, Executors
+log4j.logger.org.apache.distributedlog.util.MonitoredFuturePool=INFO, Executors
+log4j.logger.org.apache.distributedlog.util.MonitoredScheduledThreadPoolExecutor=INFO, Executors
 log4j.logger.org.apache.bookkeeper.util.SafeRunnable=INFO, Executors
-log4j.additivity.com.twitter.distributedlog.util.MonitoredFuturePool=false
-log4j.additivity.com.twitter.distributedlog.util.MonitoredScheduledThreadPoolExecutor=false
+log4j.additivity.org.apache.distributedlog.util.MonitoredFuturePool=false
+log4j.additivity.org.apache.distributedlog.util.MonitoredScheduledThreadPoolExecutor=false
 log4j.additivity.org.apache.bookkeeper.util.SafeRunnable=false
 
 log4j.appender.Executors=org.apache.log4j.RollingFileAppender