You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@bookkeeper.apache.org by sh...@apache.org on 2023/01/17 03:12:34 UTC

[bookkeeper] 01/01: unify SLASHSTAR_STYLE for licenses in Java files

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

shoothzj pushed a commit to branch 0117-slash
in repository https://gitbox.apache.org/repos/asf/bookkeeper.git

commit f3b5a6f49c629bff16d2c4d0ed8aed245a390680
Author: ZhangJian He <sh...@gmail.com>
AuthorDate: Tue Jan 17 11:12:20 2023 +0800

    unify SLASHSTAR_STYLE for licenses in Java files
---
 .../org/apache/bookkeeper/common/allocator/ByteBufAllocatorBuilder.java | 2 +-
 .../bookkeeper/common/allocator/ByteBufAllocatorWithOomHandler.java     | 2 +-
 .../org/apache/bookkeeper/common/allocator/LeakDetectionPolicy.java     | 2 +-
 .../java/org/apache/bookkeeper/common/allocator/OutOfMemoryPolicy.java  | 2 +-
 .../main/java/org/apache/bookkeeper/common/allocator/PoolingPolicy.java | 2 +-
 .../bookkeeper/common/allocator/impl/ByteBufAllocatorBuilderImpl.java   | 2 +-
 .../apache/bookkeeper/common/allocator/impl/ByteBufAllocatorImpl.java   | 2 +-
 .../java/org/apache/bookkeeper/common/allocator/impl/package-info.java  | 2 +-
 .../main/java/org/apache/bookkeeper/common/allocator/package-info.java  | 2 +-
 .../bookkeeper/common/allocator/impl/ByteBufAllocatorBuilderTest.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/common/conf/package-info.java   | 2 +-
 .../main/java/org/apache/bookkeeper/common/stats/OpStatsListener.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/common/stats/package-info.java  | 2 +-
 .../java/org/apache/bookkeeper/common/util/BoundedExecutorService.java  | 2 +-
 .../apache/bookkeeper/common/util/BoundedScheduledExecutorService.java  | 2 +-
 .../java/org/apache/bookkeeper/common/util/ExceptionMessageHelper.java  | 2 +-
 .../java/org/apache/bookkeeper/common/util/MemoryLimitController.java   | 2 +-
 .../main/java/org/apache/bookkeeper/common/util/OrderedExecutor.java    | 2 +-
 .../common/util/SingleThreadSafeScheduledExecutorService.java           | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/MathUtils.java             | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/package-info.java          | 2 +-
 .../org/apache/bookkeeper/common/util/MemoryLimitControllerTest.java    | 2 +-
 bookkeeper-proto/src/main/proto/DataFormats.proto                       | 2 +-
 bookkeeper-proto/src/main/proto/DbLedgerStorageDataFormats.proto        | 2 +-
 .../src/main/java/org/apache/bookkeeper/auth/AuthCallbacks.java         | 2 +-
 .../main/java/org/apache/bookkeeper/bookie/BookieCriticalThread.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/bookie/BookieFileChannel.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/bookie/BookieResources.java     | 2 +-
 .../src/main/java/org/apache/bookkeeper/bookie/BookieShell.java         | 2 +-
 .../src/main/java/org/apache/bookkeeper/bookie/BookieStatus.java        | 2 +-
 .../src/main/java/org/apache/bookkeeper/bookie/BookieThread.java        | 2 +-
 .../src/main/java/org/apache/bookkeeper/bookie/BufferedChannelBase.java | 2 +-
 .../src/main/java/org/apache/bookkeeper/bookie/CookieValidation.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/bookie/FileChannelProvider.java | 2 +-
 .../main/java/org/apache/bookkeeper/bookie/LegacyCookieValidation.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/AsyncCallback.java       | 2 +-
 .../org/apache/bookkeeper/client/BookieAddressResolverDisabled.java     | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/BookieInfoReader.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/BookieWatcher.java       | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/BookieWatcherImpl.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/BookiesListener.java     | 2 +-
 .../java/org/apache/bookkeeper/client/DefaultBookieAddressResolver.java | 2 +-
 .../main/java/org/apache/bookkeeper/client/DistributionSchedule.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/ForceLedgerOp.java       | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/LedgerChecker.java       | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/LedgerFragment.java      | 2 +-
 .../java/org/apache/bookkeeper/client/LedgerFragmentReplicator.java     | 2 +-
 .../main/java/org/apache/bookkeeper/client/LedgerMetadataBuilder.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/LedgerMetadataImpl.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/LedgerMetadataUtils.java | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/LedgerRecoveryOp.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/MetadataUpdateLoop.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/PendingAddOp.java        | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/PendingReadLacOp.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/PendingWriteLacOp.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/ReadLastConfirmedOp.java | 2 +-
 .../org/apache/bookkeeper/client/RoundRobinDistributionSchedule.java    | 2 +-
 .../main/java/org/apache/bookkeeper/client/TryReadLastConfirmedOp.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/UpdateLedgerOp.java      | 2 +-
 .../org/apache/bookkeeper/client/ZoneawareEnsemblePlacementPolicy.java  | 2 +-
 .../apache/bookkeeper/client/ZoneawareEnsemblePlacementPolicyImpl.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/api/LedgerEntries.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/conf/AbstractConfiguration.java | 2 +-
 .../src/main/java/org/apache/bookkeeper/conf/ClientConfiguration.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/conf/ServerConfiguration.java   | 2 +-
 .../org/apache/bookkeeper/meta/AbstractHierarchicalLedgerManager.java   | 2 +-
 .../main/java/org/apache/bookkeeper/meta/AbstractZkLedgerManager.java   | 2 +-
 .../java/org/apache/bookkeeper/meta/AbstractZkLedgerManagerFactory.java | 2 +-
 .../src/main/java/org/apache/bookkeeper/meta/CleanupLedgerManager.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/meta/FlatLedgerManager.java     | 2 +-
 .../main/java/org/apache/bookkeeper/meta/FlatLedgerManagerFactory.java  | 2 +-
 .../main/java/org/apache/bookkeeper/meta/HierarchicalLedgerManager.java | 2 +-
 .../org/apache/bookkeeper/meta/HierarchicalLedgerManagerFactory.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/meta/LedgerAuditorManager.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/meta/LedgerIdGenerator.java     | 2 +-
 .../src/main/java/org/apache/bookkeeper/meta/LedgerLayout.java          | 2 +-
 .../src/main/java/org/apache/bookkeeper/meta/LedgerManager.java         | 2 +-
 .../src/main/java/org/apache/bookkeeper/meta/LedgerManagerFactory.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/meta/LedgerMetadataSerDe.java   | 2 +-
 .../java/org/apache/bookkeeper/meta/LedgerUnderreplicationManager.java  | 2 +-
 .../org/apache/bookkeeper/meta/LegacyHierarchicalLedgerManager.java     | 2 +-
 .../apache/bookkeeper/meta/LegacyHierarchicalLedgerManagerFactory.java  | 2 +-
 .../java/org/apache/bookkeeper/meta/LongHierarchicalLedgerManager.java  | 2 +-
 .../apache/bookkeeper/meta/LongHierarchicalLedgerManagerFactory.java    | 2 +-
 .../main/java/org/apache/bookkeeper/meta/LongZkLedgerIdGenerator.java   | 2 +-
 .../main/java/org/apache/bookkeeper/meta/MSLedgerManagerFactory.java    | 2 +-
 .../main/java/org/apache/bookkeeper/meta/NullMetadataBookieDriver.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/meta/UnderreplicatedLedger.java | 2 +-
 .../main/java/org/apache/bookkeeper/meta/ZkLedgerAuditorManager.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/meta/ZkLedgerIdGenerator.java   | 2 +-
 .../org/apache/bookkeeper/meta/ZkLedgerUnderreplicationManager.java     | 2 +-
 .../main/java/org/apache/bookkeeper/metastore/InMemoryMetaStore.java    | 2 +-
 .../java/org/apache/bookkeeper/metastore/InMemoryMetastoreCursor.java   | 2 +-
 .../java/org/apache/bookkeeper/metastore/InMemoryMetastoreTable.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/metastore/MSException.java      | 2 +-
 .../src/main/java/org/apache/bookkeeper/metastore/MSWatchedEvent.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/metastore/MetaStore.java        | 2 +-
 .../main/java/org/apache/bookkeeper/metastore/MetastoreCallback.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/metastore/MetastoreCursor.java  | 2 +-
 .../main/java/org/apache/bookkeeper/metastore/MetastoreException.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/metastore/MetastoreFactory.java | 2 +-
 .../java/org/apache/bookkeeper/metastore/MetastoreScannableTable.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/metastore/MetastoreTable.java   | 2 +-
 .../main/java/org/apache/bookkeeper/metastore/MetastoreTableItem.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/metastore/MetastoreUtils.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/metastore/MetastoreWatcher.java | 2 +-
 .../src/main/java/org/apache/bookkeeper/metastore/Value.java            | 2 +-
 .../main/java/org/apache/bookkeeper/net/AbstractDNSToSwitchMapping.java | 2 +-
 .../src/main/java/org/apache/bookkeeper/net/BookieNode.java             | 2 +-
 .../main/java/org/apache/bookkeeper/net/CachedDNSToSwitchMapping.java   | 2 +-
 bookkeeper-server/src/main/java/org/apache/bookkeeper/net/DNS.java      | 2 +-
 .../src/main/java/org/apache/bookkeeper/net/DNSToSwitchMapping.java     | 2 +-
 bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NetUtils.java | 2 +-
 .../src/main/java/org/apache/bookkeeper/net/NetworkTopologyImpl.java    | 2 +-
 bookkeeper-server/src/main/java/org/apache/bookkeeper/net/Node.java     | 2 +-
 bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NodeBase.java | 2 +-
 .../src/main/java/org/apache/bookkeeper/net/ScriptBasedMapping.java     | 2 +-
 .../java/org/apache/bookkeeper/proto/LongPollReadEntryProcessorV3.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/proto/PacketProcessorBase.java  | 2 +-
 .../main/java/org/apache/bookkeeper/proto/PerChannelBookieClient.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/proto/ReadEntryProcessor.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/proto/ReadEntryProcessorV3.java | 2 +-
 .../src/main/java/org/apache/bookkeeper/proto/RequestUtils.java         | 2 +-
 .../src/main/java/org/apache/bookkeeper/proto/WriteEntryProcessor.java  | 2 +-
 .../main/java/org/apache/bookkeeper/proto/checksum/DigestManager.java   | 2 +-
 .../java/org/apache/bookkeeper/replication/BookieLedgerIndexer.java     | 2 +-
 .../java/org/apache/bookkeeper/replication/ReplicationException.java    | 2 +-
 .../main/java/org/apache/bookkeeper/replication/ReplicationWorker.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/tls/BookieAuthZFactory.java     | 2 +-
 .../main/java/org/apache/bookkeeper/tls/FileModifiedTimeUpdater.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/tls/SecurityException.java      | 2 +-
 .../src/main/java/org/apache/bookkeeper/tls/SecurityHandlerFactory.java | 2 +-
 .../java/org/apache/bookkeeper/tls/SecurityProviderFactoryFactory.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/tls/TLSContextFactory.java      | 2 +-
 .../apache/bookkeeper/tools/cli/commands/autorecovery/package-info.java | 2 +-
 .../bookkeeper/tools/cli/commands/bookie/ListActiveLedgersCommand.java  | 2 +-
 .../org/apache/bookkeeper/tools/cli/commands/health/package-info.java   | 2 +-
 .../java/org/apache/bookkeeper/util/AvailabilityOfEntriesOfLedger.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/BookKeeperConstants.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/CertUtils.java             | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/DaemonThreadFactory.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/DiskChecker.java           | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/EventLoopUtil.java         | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/HardLink.java              | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/LocalBookKeeper.java       | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/NativeIO.java              | 2 +-
 .../main/java/org/apache/bookkeeper/util/OrderedGenericCallback.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/SafeRunnable.java          | 2 +-
 bookkeeper-server/src/main/java/org/apache/bookkeeper/util/Shell.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/SnapshotMap.java           | 2 +-
 .../src/main/java/org/apache/bookkeeper/util/StringUtils.java           | 2 +-
 bookkeeper-server/src/main/java/org/apache/bookkeeper/util/Tool.java    | 2 +-
 .../main/java/org/apache/bookkeeper/verifier/BookkeeperVerifier.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/versioning/Versioned.java       | 2 +-
 .../src/test/java/org/apache/bookkeeper/bookie/BookieThreadTest.java    | 2 +-
 .../src/test/java/org/apache/bookkeeper/bookie/CreateNewLogTest.java    | 2 +-
 .../bookkeeper/bookie/storage/ldb/KeyValueStorageRocksDBTest.java       | 2 +-
 .../org/apache/bookkeeper/client/BookieRecoveryUseIOThreadTest.java     | 2 +-
 .../src/test/java/org/apache/bookkeeper/client/ClientUtil.java          | 2 +-
 .../src/test/java/org/apache/bookkeeper/client/LedgerHandleAdapter.java | 2 +-
 .../src/test/java/org/apache/bookkeeper/client/ListLedgersTest.java     | 2 +-
 .../test/java/org/apache/bookkeeper/client/MetadataUpdateLoopTest.java  | 2 +-
 .../src/test/java/org/apache/bookkeeper/client/MockBookKeeper.java      | 2 +-
 .../src/test/java/org/apache/bookkeeper/client/MockBookKeeperTest.java  | 2 +-
 .../test/java/org/apache/bookkeeper/client/MockBookKeeperTestCase.java  | 2 +-
 .../src/test/java/org/apache/bookkeeper/client/MockLedgerEntry.java     | 2 +-
 .../src/test/java/org/apache/bookkeeper/client/MockLedgerHandle.java    | 2 +-
 .../src/test/java/org/apache/bookkeeper/client/MockReadHandle.java      | 2 +-
 .../org/apache/bookkeeper/client/TestLedgerFragmentReplication.java     | 2 +-
 .../test/java/org/apache/bookkeeper/client/TestMaxSizeWorkersQueue.java | 2 +-
 .../src/test/java/org/apache/bookkeeper/meta/MockLedgerManager.java     | 2 +-
 .../test/java/org/apache/bookkeeper/meta/TestLedgerMetadataSerDe.java   | 2 +-
 .../java/org/apache/bookkeeper/meta/TestLongZkLedgerIdGenerator.java    | 2 +-
 .../test/java/org/apache/bookkeeper/meta/TestZkLedgerIdGenerator.java   | 2 +-
 .../metastore/MetastoreScannableTableAsyncToSyncConverter.java          | 2 +-
 .../apache/bookkeeper/metastore/MetastoreTableAsyncToSyncConverter.java | 2 +-
 .../src/test/java/org/apache/bookkeeper/metastore/TestMetaStore.java    | 2 +-
 .../java/org/apache/bookkeeper/proto/BookieBackpressureForV2Test.java   | 2 +-
 .../java/org/apache/bookkeeper/replication/BookieAutoRecoveryTest.java  | 2 +-
 .../java/org/apache/bookkeeper/replication/BookieLedgerIndexTest.java   | 2 +-
 .../java/org/apache/bookkeeper/replication/TestReplicationWorker.java   | 2 +-
 bookkeeper-server/src/test/java/org/apache/bookkeeper/sasl/MiniKdc.java | 2 +-
 .../src/test/java/org/apache/bookkeeper/tls/TestBookieAuthZFactory.java | 2 +-
 bookkeeper-server/src/test/java/org/apache/bookkeeper/tls/TestTLS.java  | 2 +-
 .../src/test/java/org/apache/bookkeeper/util/TestDiskChecker.java       | 2 +-
 .../src/main/java/com/scurrilous/circe/utils/NativeUtils.java           | 2 +-
 .../src/test/java/com/scurrilous/circe/utils/NativeUtilsTests.java      | 2 +-
 .../main/java/org/apache/bookkeeper/metadata/etcd/EtcdConstants.java    | 2 +-
 .../java/org/apache/bookkeeper/proto/checksum/DigestTypeBenchmark.java  | 2 +-
 .../main/java/org/apache/bookkeeper/stats/codahale/TimerBenchmark.java  | 2 +-
 .../main/java/org/apache/bookkeeper/common/util/nativeio/NativeIO.java  | 2 +-
 .../java/org/apache/bookkeeper/common/util/nativeio/NativeUtils.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/AlertStatsLogger.java     | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/CachingStatsLogger.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/CachingStatsProvider.java | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/Counter.java              | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/Gauge.java                | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/NullStatsLogger.java      | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/NullStatsProvider.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/OpStatsData.java          | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/OpStatsLogger.java        | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/StatsLogger.java          | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/StatsProvider.java        | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/ThreadRegistry.java       | 2 +-
 .../org/apache/bookkeeper/stats/codahale/CodahaleMetricsProvider.java   | 2 +-
 .../org/apache/bookkeeper/stats/codahale/CodahaleOpStatsLogger.java     | 2 +-
 .../java/org/apache/bookkeeper/stats/codahale/CodahaleStatsLogger.java  | 2 +-
 .../apache/bookkeeper/stats/codahale/FastCodahaleMetricsProvider.java   | 2 +-
 .../org/apache/bookkeeper/stats/codahale/FastCodahaleStatsLogger.java   | 2 +-
 .../main/java/org/apache/bookkeeper/stats/codahale/FastSnapshot.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/stats/codahale/FastTimer.java   | 2 +-
 .../java/org/apache/bookkeeper/stats/codahale/CodahaleOpStatsTest.java  | 2 +-
 .../test/java/org/apache/bookkeeper/stats/codahale/FastTimerTest.java   | 2 +-
 .../apache/bookkeeper/stats/prometheus/DataSketchesOpStatsLogger.java   | 2 +-
 .../java/org/apache/bookkeeper/stats/prometheus/LongAdderCounter.java   | 2 +-
 .../apache/bookkeeper/stats/prometheus/PrometheusMetricsProvider.java   | 2 +-
 .../java/org/apache/bookkeeper/stats/prometheus/PrometheusServlet.java  | 2 +-
 .../org/apache/bookkeeper/stats/prometheus/PrometheusStatsLogger.java   | 2 +-
 .../org/apache/bookkeeper/stats/prometheus/PrometheusTextFormat.java    | 2 +-
 .../main/java/org/apache/bookkeeper/stats/prometheus/ScopeContext.java  | 2 +-
 .../main/java/org/apache/bookkeeper/stats/prometheus/SimpleGauge.java   | 2 +-
 .../stats/prometheus/ThreadScopedDataSketchesStatsLogger.java           | 2 +-
 .../bookkeeper/stats/prometheus/ThreadScopedLongAdderCounter.java       | 2 +-
 .../apache/bookkeeper/stats/prometheus/PrometheusTextFormatTest.java    | 2 +-
 .../org/apache/bookkeeper/stats/prometheus/TestPrometheusFormatter.java | 2 +-
 .../bookkeeper/stats/prometheus/TestPrometheusMetricsProvider.java      | 2 +-
 stream/api/src/main/java/org/apache/bookkeeper/api/kv/package-info.java | 2 +-
 .../all/src/main/java/org/apache/bookkeeper/clients/package-info.java   | 2 +-
 .../java/org/apache/bookkeeper/clients/impl/channel/package-info.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/common/hash/package-info.java   | 2 +-
 .../java/org/apache/bookkeeper/common/router/AbstractHashRouter.java    | 2 +-
 .../src/main/java/org/apache/bookkeeper/common/router/HashRouter.java   | 2 +-
 .../java/org/apache/bookkeeper/common/router/StringUtf8HashRouter.java  | 2 +-
 .../src/main/java/org/apache/bookkeeper/common/router/package-info.java | 2 +-
 .../common/src/main/java/org/apache/bookkeeper/common/util/Bytes.java   | 2 +-
 .../src/main/java/org/apache/bookkeeper/common/util/IRevisioned.java    | 2 +-
 .../distributedlog/common/annotations/DistributedLogAnnotations.java    | 2 +-
 .../java/org/apache/distributedlog/common/annotations/package-info.java | 2 +-
 .../org/apache/distributedlog/common/concurrent/AsyncSemaphore.java     | 2 +-
 .../java/org/apache/distributedlog/common/rate/MovingAverageRate.java   | 2 +-
 .../org/apache/distributedlog/common/rate/MovingAverageRateFactory.java | 2 +-
 .../org/apache/distributedlog/common/rate/SampledMovingAverageRate.java | 2 +-
 .../java/org/apache/distributedlog/common/stats/OpStatsListener.java    | 2 +-
 .../main/java/org/apache/distributedlog/common/stats/package-info.java  | 2 +-
 .../main/java/org/apache/distributedlog/common/util/BitMaskUtils.java   | 2 +-
 .../src/main/java/org/apache/distributedlog/common/util/MathUtil.java   | 2 +-
 .../src/main/java/org/apache/distributedlog/common/util/Permit.java     | 2 +-
 .../java/org/apache/distributedlog/common/util/ReferenceCounted.java    | 2 +-
 .../src/main/java/org/apache/distributedlog/io/AsyncCloseable.java      | 2 +-
 .../src/main/java/org/apache/distributedlog/io/AsyncDeleteable.java     | 2 +-
 .../src/main/java/org/apache/distributedlog/io/CompressionCodec.java    | 2 +-
 .../src/main/java/org/apache/distributedlog/io/CompressionUtils.java    | 2 +-
 .../java/org/apache/distributedlog/io/IdentityCompressionCodec.java     | 2 +-
 .../src/main/java/org/apache/distributedlog/io/LZ4CompressionCodec.java | 2 +-
 .../src/main/java/org/apache/bookkeeper/client/BookKeeperAccessor.java  | 2 +-
 .../core/src/main/java/org/apache/bookkeeper/client/LedgerReader.java   | 2 +-
 .../src/main/java/org/apache/distributedlog/AppendOnlyStreamReader.java | 2 +-
 .../src/main/java/org/apache/distributedlog/AppendOnlyStreamWriter.java | 2 +-
 .../core/src/main/java/org/apache/distributedlog/AsyncNotification.java | 2 +-
 .../src/main/java/org/apache/distributedlog/BKAbstractLogWriter.java    | 2 +-
 .../core/src/main/java/org/apache/distributedlog/BKAsyncLogReader.java  | 2 +-
 .../core/src/main/java/org/apache/distributedlog/BKAsyncLogWriter.java  | 2 +-
 .../main/java/org/apache/distributedlog/BKDistributedLogManager.java    | 2 +-
 .../main/java/org/apache/distributedlog/BKDistributedLogNamespace.java  | 2 +-
 .../core/src/main/java/org/apache/distributedlog/BKLogHandler.java      | 2 +-
 .../core/src/main/java/org/apache/distributedlog/BKLogReadHandler.java  | 2 +-
 .../src/main/java/org/apache/distributedlog/BKLogSegmentWriter.java     | 2 +-
 .../core/src/main/java/org/apache/distributedlog/BKLogWriteHandler.java | 2 +-
 .../core/src/main/java/org/apache/distributedlog/BKSyncLogReader.java   | 2 +-
 .../core/src/main/java/org/apache/distributedlog/BKSyncLogWriter.java   | 2 +-
 .../core/src/main/java/org/apache/distributedlog/BKTransmitPacket.java  | 2 +-
 .../core/src/main/java/org/apache/distributedlog/BookKeeperClient.java  | 2 +-
 .../main/java/org/apache/distributedlog/BookKeeperClientBuilder.java    | 2 +-
 .../java/org/apache/distributedlog/DistributedLogConfiguration.java     | 2 +-
 .../main/java/org/apache/distributedlog/DistributedLogConstants.java    | 2 +-
 .../core/src/main/java/org/apache/distributedlog/Entry.java             | 2 +-
 .../core/src/main/java/org/apache/distributedlog/EntryBuffer.java       | 2 +-
 .../core/src/main/java/org/apache/distributedlog/EntryPosition.java     | 2 +-
 .../core/src/main/java/org/apache/distributedlog/EnvelopedEntry.java    | 2 +-
 .../src/main/java/org/apache/distributedlog/EnvelopedEntryReader.java   | 2 +-
 .../src/main/java/org/apache/distributedlog/EnvelopedEntryWriter.java   | 2 +-
 .../core/src/main/java/org/apache/distributedlog/LocalDLMEmulator.java  | 2 +-
 .../src/main/java/org/apache/distributedlog/LogSegmentMetadata.java     | 2 +-
 .../main/java/org/apache/distributedlog/MaxLogSegmentSequenceNo.java    | 2 +-
 .../core/src/main/java/org/apache/distributedlog/MaxTxId.java           | 2 +-
 .../src/main/java/org/apache/distributedlog/ReadAheadEntryReader.java   | 2 +-
 .../core/src/main/java/org/apache/distributedlog/ReadUtils.java         | 2 +-
 .../core/src/main/java/org/apache/distributedlog/WriteLimiter.java      | 2 +-
 .../core/src/main/java/org/apache/distributedlog/ZooKeeperClient.java   | 2 +-
 .../src/main/java/org/apache/distributedlog/ZooKeeperClientBuilder.java | 2 +-
 .../main/java/org/apache/distributedlog/acl/AccessControlManager.java   | 2 +-
 .../java/org/apache/distributedlog/acl/DefaultAccessControlManager.java | 2 +-
 .../core/src/main/java/org/apache/distributedlog/acl/package-info.java  | 2 +-
 .../main/java/org/apache/distributedlog/admin/DistributedLogAdmin.java  | 2 +-
 .../src/main/java/org/apache/distributedlog/admin/package-info.java     | 2 +-
 .../apache/distributedlog/api/subscription/SubscriptionStateStore.java  | 2 +-
 .../org/apache/distributedlog/api/subscription/SubscriptionsStore.java  | 2 +-
 .../core/src/main/java/org/apache/distributedlog/auditor/DLAuditor.java | 2 +-
 .../java/org/apache/distributedlog/bk/DynamicQuorumConfigProvider.java  | 2 +-
 .../org/apache/distributedlog/bk/ImmutableQuorumConfigProvider.java     | 2 +-
 .../src/main/java/org/apache/distributedlog/bk/LedgerAllocator.java     | 2 +-
 .../java/org/apache/distributedlog/bk/LedgerAllocatorDelegator.java     | 2 +-
 .../src/main/java/org/apache/distributedlog/bk/LedgerAllocatorPool.java | 2 +-
 .../main/java/org/apache/distributedlog/bk/LedgerAllocatorUtils.java    | 2 +-
 .../core/src/main/java/org/apache/distributedlog/bk/QuorumConfig.java   | 2 +-
 .../main/java/org/apache/distributedlog/bk/QuorumConfigProvider.java    | 2 +-
 .../main/java/org/apache/distributedlog/bk/SimpleLedgerAllocator.java   | 2 +-
 .../core/src/main/java/org/apache/distributedlog/bk/package-info.java   | 2 +-
 .../java/org/apache/distributedlog/callback/LogSegmentListener.java     | 2 +-
 .../org/apache/distributedlog/callback/LogSegmentNamesListener.java     | 2 +-
 .../main/java/org/apache/distributedlog/callback/NamespaceListener.java | 2 +-
 .../src/main/java/org/apache/distributedlog/callback/package-info.java  | 2 +-
 .../org/apache/distributedlog/config/DynamicConfigurationFactory.java   | 2 +-
 .../distributedlog/config/DynamicDistributedLogConfiguration.java       | 2 +-
 .../src/main/java/org/apache/distributedlog/config/package-info.java    | 2 +-
 .../src/main/java/org/apache/distributedlog/exceptions/ZKException.java | 2 +-
 .../main/java/org/apache/distributedlog/exceptions/package-info.java    | 2 +-
 .../java/org/apache/distributedlog/feature/AbstractFeatureProvider.java | 2 +-
 .../org/apache/distributedlog/feature/ConfigurationFeatureProvider.java | 2 +-
 .../main/java/org/apache/distributedlog/feature/CoreFeatureKeys.java    | 2 +-
 .../java/org/apache/distributedlog/feature/DefaultFeatureProvider.java  | 2 +-
 .../distributedlog/feature/DynamicConfigurationFeatureProvider.java     | 2 +-
 .../src/main/java/org/apache/distributedlog/feature/package-info.java   | 2 +-
 .../java/org/apache/distributedlog/function/GetLastTxIdFunction.java    | 2 +-
 .../src/main/java/org/apache/distributedlog/function/package-info.java  | 2 +-
 .../src/main/java/org/apache/distributedlog/impl/BKNamespaceDriver.java | 2 +-
 .../main/java/org/apache/distributedlog/impl/ZKLogMetadataStore.java    | 2 +-
 .../main/java/org/apache/distributedlog/impl/ZKLogSegmentFilters.java   | 2 +-
 .../java/org/apache/distributedlog/impl/ZKLogSegmentMetadataStore.java  | 2 +-
 .../main/java/org/apache/distributedlog/impl/ZKMetadataAccessor.java    | 2 +-
 .../main/java/org/apache/distributedlog/impl/ZKNamespaceWatcher.java    | 2 +-
 .../main/java/org/apache/distributedlog/impl/acl/ZKAccessControl.java   | 2 +-
 .../java/org/apache/distributedlog/impl/acl/ZKAccessControlManager.java | 2 +-
 .../src/main/java/org/apache/distributedlog/impl/acl/package-info.java  | 2 +-
 .../distributedlog/impl/federated/FederatedZKLogMetadataStore.java      | 2 +-
 .../java/org/apache/distributedlog/impl/federated/package-info.java     | 2 +-
 .../apache/distributedlog/impl/logsegment/BKLogSegmentAllocator.java    | 2 +-
 .../apache/distributedlog/impl/logsegment/BKLogSegmentEntryReader.java  | 2 +-
 .../apache/distributedlog/impl/logsegment/BKLogSegmentEntryStore.java   | 2 +-
 .../apache/distributedlog/impl/logsegment/BKLogSegmentEntryWriter.java  | 2 +-
 .../impl/logsegment/BKLogSegmentRandomAccessEntryReader.java            | 2 +-
 .../main/java/org/apache/distributedlog/impl/logsegment/BKUtils.java    | 2 +-
 .../java/org/apache/distributedlog/impl/logsegment/package-info.java    | 2 +-
 .../main/java/org/apache/distributedlog/impl/metadata/BKDLConfig.java   | 2 +-
 .../apache/distributedlog/impl/metadata/ZKLogStreamMetadataStore.java   | 2 +-
 .../org/apache/distributedlog/impl/metadata/ZkMetadataResolver.java     | 2 +-
 .../main/java/org/apache/distributedlog/impl/metadata/package-info.java | 2 +-
 .../core/src/main/java/org/apache/distributedlog/impl/package-info.java | 2 +-
 .../distributedlog/impl/subscription/ZKSubscriptionStateStore.java      | 2 +-
 .../apache/distributedlog/impl/subscription/ZKSubscriptionsStore.java   | 2 +-
 .../java/org/apache/distributedlog/impl/subscription/package-info.java  | 2 +-
 .../java/org/apache/distributedlog/injector/AsyncFailureInjector.java   | 2 +-
 .../org/apache/distributedlog/injector/AsyncRandomFailureInjector.java  | 2 +-
 .../main/java/org/apache/distributedlog/injector/FailureInjector.java   | 2 +-
 .../org/apache/distributedlog/injector/RandomDelayFailureInjector.java  | 2 +-
 .../src/main/java/org/apache/distributedlog/injector/package-info.java  | 2 +-
 .../java/org/apache/distributedlog/limiter/ChainedRequestLimiter.java   | 2 +-
 .../org/apache/distributedlog/limiter/ComposableRequestLimiter.java     | 2 +-
 .../main/java/org/apache/distributedlog/limiter/GuavaRateLimiter.java   | 2 +-
 .../src/main/java/org/apache/distributedlog/limiter/RateLimiter.java    | 2 +-
 .../src/main/java/org/apache/distributedlog/limiter/RequestLimiter.java | 2 +-
 .../src/main/java/org/apache/distributedlog/limiter/package-info.java   | 2 +-
 .../src/main/java/org/apache/distributedlog/lock/DistributedLock.java   | 2 +-
 .../java/org/apache/distributedlog/lock/DistributedLockContext.java     | 2 +-
 .../main/java/org/apache/distributedlog/lock/EpochChangedException.java | 2 +-
 .../core/src/main/java/org/apache/distributedlog/lock/LockAction.java   | 2 +-
 .../main/java/org/apache/distributedlog/lock/LockClosedException.java   | 2 +-
 .../core/src/main/java/org/apache/distributedlog/lock/LockListener.java | 2 +-
 .../org/apache/distributedlog/lock/LockSessionExpiredException.java     | 2 +-
 .../java/org/apache/distributedlog/lock/LockStateChangedException.java  | 2 +-
 .../main/java/org/apache/distributedlog/lock/LockTimeoutException.java  | 2 +-
 .../core/src/main/java/org/apache/distributedlog/lock/LockWaiter.java   | 2 +-
 .../main/java/org/apache/distributedlog/lock/NopDistributedLock.java    | 2 +-
 .../core/src/main/java/org/apache/distributedlog/lock/SessionLock.java  | 2 +-
 .../main/java/org/apache/distributedlog/lock/SessionLockFactory.java    | 2 +-
 .../src/main/java/org/apache/distributedlog/lock/ZKDistributedLock.java | 2 +-
 .../src/main/java/org/apache/distributedlog/lock/ZKSessionLock.java     | 2 +-
 .../main/java/org/apache/distributedlog/lock/ZKSessionLockFactory.java  | 2 +-
 .../core/src/main/java/org/apache/distributedlog/lock/package-info.java | 2 +-
 .../org/apache/distributedlog/logsegment/LogSegmentEntryReader.java     | 2 +-
 .../java/org/apache/distributedlog/logsegment/LogSegmentEntryStore.java | 2 +-
 .../org/apache/distributedlog/logsegment/LogSegmentEntryWriter.java     | 2 +-
 .../java/org/apache/distributedlog/logsegment/LogSegmentFilter.java     | 2 +-
 .../org/apache/distributedlog/logsegment/LogSegmentMetadataCache.java   | 2 +-
 .../org/apache/distributedlog/logsegment/LogSegmentMetadataStore.java   | 2 +-
 .../distributedlog/logsegment/LogSegmentRandomAccessEntryReader.java    | 2 +-
 .../java/org/apache/distributedlog/logsegment/LogSegmentWriter.java     | 2 +-
 .../org/apache/distributedlog/logsegment/PerStreamLogSegmentCache.java  | 2 +-
 .../main/java/org/apache/distributedlog/logsegment/RollingPolicy.java   | 2 +-
 .../org/apache/distributedlog/logsegment/SizeBasedRollingPolicy.java    | 2 +-
 .../org/apache/distributedlog/logsegment/TimeBasedRollingPolicy.java    | 2 +-
 .../main/java/org/apache/distributedlog/logsegment/package-info.java    | 2 +-
 .../core/src/main/java/org/apache/distributedlog/metadata/DLConfig.java | 2 +-
 .../src/main/java/org/apache/distributedlog/metadata/DLMetadata.java    | 2 +-
 .../distributedlog/metadata/DryrunLogSegmentMetadataStoreUpdater.java   | 2 +-
 .../src/main/java/org/apache/distributedlog/metadata/LogMetadata.java   | 2 +-
 .../java/org/apache/distributedlog/metadata/LogMetadataForReader.java   | 2 +-
 .../java/org/apache/distributedlog/metadata/LogMetadataForWriter.java   | 2 +-
 .../main/java/org/apache/distributedlog/metadata/LogMetadataStore.java  | 2 +-
 .../apache/distributedlog/metadata/LogSegmentMetadataStoreUpdater.java  | 2 +-
 .../java/org/apache/distributedlog/metadata/LogStreamMetadataStore.java | 2 +-
 .../main/java/org/apache/distributedlog/metadata/MetadataResolver.java  | 2 +-
 .../main/java/org/apache/distributedlog/metadata/MetadataUpdater.java   | 2 +-
 .../src/main/java/org/apache/distributedlog/metadata/package-info.java  | 2 +-
 .../main/java/org/apache/distributedlog/namespace/NamespaceDriver.java  | 2 +-
 .../org/apache/distributedlog/namespace/NamespaceDriverManager.java     | 2 +-
 .../main/java/org/apache/distributedlog/namespace/NamespaceWatcher.java | 2 +-
 .../src/main/java/org/apache/distributedlog/namespace/package-info.java | 2 +-
 .../core/src/main/java/org/apache/distributedlog/net/DNSResolver.java   | 2 +-
 .../main/java/org/apache/distributedlog/net/DNSResolverForRacks.java    | 2 +-
 .../src/main/java/org/apache/distributedlog/net/DNSResolverForRows.java | 2 +-
 .../core/src/main/java/org/apache/distributedlog/net/NetUtils.java      | 2 +-
 .../core/src/main/java/org/apache/distributedlog/net/package-info.java  | 2 +-
 .../core/src/main/java/org/apache/distributedlog/package-info.java      | 2 +-
 .../apache/distributedlog/selector/FirstDLSNNotLessThanSelector.java    | 2 +-
 .../java/org/apache/distributedlog/selector/FirstRecordSelector.java    | 2 +-
 .../apache/distributedlog/selector/FirstTxIdNotLessThanSelector.java    | 2 +-
 .../java/org/apache/distributedlog/selector/LastRecordSelector.java     | 2 +-
 .../main/java/org/apache/distributedlog/selector/LogRecordSelector.java | 2 +-
 .../src/main/java/org/apache/distributedlog/selector/package-info.java  | 2 +-
 .../src/main/java/org/apache/distributedlog/thrift/package-info.java    | 2 +-
 .../main/java/org/apache/distributedlog/tools/DistributedLogTool.java   | 2 +-
 .../core/src/main/java/org/apache/distributedlog/tools/Tool.java        | 2 +-
 .../src/main/java/org/apache/distributedlog/tools/package-info.java     | 2 +-
 .../core/src/main/java/org/apache/distributedlog/util/Allocator.java    | 2 +-
 .../src/main/java/org/apache/distributedlog/util/CommandLineUtils.java  | 2 +-
 .../core/src/main/java/org/apache/distributedlog/util/ConfUtils.java    | 2 +-
 .../core/src/main/java/org/apache/distributedlog/util/DLUtils.java      | 2 +-
 .../src/main/java/org/apache/distributedlog/util/FailpointUtils.java    | 2 +-
 .../src/main/java/org/apache/distributedlog/util/RetryPolicyUtils.java  | 2 +-
 .../src/main/java/org/apache/distributedlog/util/TimeSequencer.java     | 2 +-
 .../core/src/main/java/org/apache/distributedlog/util/Utils.java        | 2 +-
 .../core/src/main/java/org/apache/distributedlog/util/package-info.java | 2 +-
 .../core/src/main/java/org/apache/distributedlog/zk/DefaultZKOp.java    | 2 +-
 .../main/java/org/apache/distributedlog/zk/LimitedPermitManager.java    | 2 +-
 .../core/src/main/java/org/apache/distributedlog/zk/ZKOp.java           | 2 +-
 .../core/src/main/java/org/apache/distributedlog/zk/ZKTransaction.java  | 2 +-
 .../src/main/java/org/apache/distributedlog/zk/ZKVersionedSetOp.java    | 2 +-
 .../src/main/java/org/apache/distributedlog/zk/ZKWatcherManager.java    | 2 +-
 .../core/src/main/java/org/apache/distributedlog/zk/package-info.java   | 2 +-
 stream/distributedlog/core/src/main/thrift/metadata.thrift              | 2 +-
 .../core/src/test/java/org/apache/distributedlog/DLMTestUtil.java       | 2 +-
 .../test/java/org/apache/distributedlog/NonBlockingReadsTestUtil.java   | 2 +-
 .../test/java/org/apache/distributedlog/TestAppendOnlyStreamReader.java | 2 +-
 .../test/java/org/apache/distributedlog/TestAppendOnlyStreamWriter.java | 2 +-
 .../src/test/java/org/apache/distributedlog/TestAsyncBulkWrite.java     | 2 +-
 .../src/test/java/org/apache/distributedlog/TestAsyncReaderLock.java    | 2 +-
 .../src/test/java/org/apache/distributedlog/TestAsyncReaderWriter.java  | 2 +-
 .../java/org/apache/distributedlog/TestBKDistributedLogManager.java     | 2 +-
 .../java/org/apache/distributedlog/TestBKDistributedLogNamespace.java   | 2 +-
 .../src/test/java/org/apache/distributedlog/TestBKLogReadHandler.java   | 2 +-
 .../src/test/java/org/apache/distributedlog/TestBKLogSegmentWriter.java | 2 +-
 .../src/test/java/org/apache/distributedlog/TestBKLogWriteHandler.java  | 2 +-
 .../src/test/java/org/apache/distributedlog/TestBKSyncLogReader.java    | 2 +-
 .../core/src/test/java/org/apache/distributedlog/TestCancelledRead.java | 2 +-
 .../core/src/test/java/org/apache/distributedlog/TestDLMTestUtil.java   | 2 +-
 .../src/test/java/org/apache/distributedlog/TestDistributedLogBase.java | 2 +-
 .../java/org/apache/distributedlog/TestDistributedLogConfiguration.java | 2 +-
 .../core/src/test/java/org/apache/distributedlog/TestEntry.java         | 2 +-
 .../core/src/test/java/org/apache/distributedlog/TestEntryPosition.java | 2 +-
 .../src/test/java/org/apache/distributedlog/TestInterleavedReaders.java | 2 +-
 .../src/test/java/org/apache/distributedlog/TestLogSegmentCreation.java | 2 +-
 .../src/test/java/org/apache/distributedlog/TestLogSegmentMetadata.java | 2 +-
 .../core/src/test/java/org/apache/distributedlog/TestLogSegmentsZK.java | 2 +-
 .../src/test/java/org/apache/distributedlog/TestNonBlockingReads.java   | 2 +-
 .../java/org/apache/distributedlog/TestNonBlockingReadsMultiReader.java | 2 +-
 .../test/java/org/apache/distributedlog/TestReadAheadEntryReader.java   | 2 +-
 .../core/src/test/java/org/apache/distributedlog/TestReadUtils.java     | 2 +-
 .../core/src/test/java/org/apache/distributedlog/TestReader.java        | 2 +-
 .../src/test/java/org/apache/distributedlog/TestRollLogSegments.java    | 2 +-
 .../core/src/test/java/org/apache/distributedlog/TestSequenceID.java    | 2 +-
 .../core/src/test/java/org/apache/distributedlog/TestTruncate.java      | 2 +-
 .../core/src/test/java/org/apache/distributedlog/TestTxnId.java         | 2 +-
 .../core/src/test/java/org/apache/distributedlog/TestWriteLimiter.java  | 2 +-
 .../src/test/java/org/apache/distributedlog/TestZooKeeperClient.java    | 2 +-
 .../test/java/org/apache/distributedlog/TestZooKeeperClientBuilder.java | 2 +-
 .../src/test/java/org/apache/distributedlog/ZooKeeperClientUtils.java   | 2 +-
 .../test/java/org/apache/distributedlog/ZooKeeperClusterTestCase.java   | 2 +-
 .../test/java/org/apache/distributedlog/acl/TestZKAccessControl.java    | 2 +-
 .../java/org/apache/distributedlog/acl/TestZKAccessControlManager.java  | 2 +-
 .../core/src/test/java/org/apache/distributedlog/admin/TestDLCK.java    | 2 +-
 .../java/org/apache/distributedlog/admin/TestDistributedLogAdmin.java   | 2 +-
 .../src/test/java/org/apache/distributedlog/bk/TestLedgerAllocator.java | 2 +-
 .../test/java/org/apache/distributedlog/bk/TestLedgerAllocatorPool.java | 2 +-
 .../apache/distributedlog/config/TestDynamicConfigurationFactory.java   | 2 +-
 .../distributedlog/config/TestDynamicDistributedLogConfiguration.java   | 2 +-
 .../apache/distributedlog/feature/TestConfigurationFeatureProvider.java | 2 +-
 .../distributedlog/feature/TestDynamicConfigurationFeatureProvider.java | 2 +-
 .../java/org/apache/distributedlog/impl/TestZKLogMetadataStore.java     | 2 +-
 .../java/org/apache/distributedlog/impl/TestZKLogSegmentFilters.java    | 2 +-
 .../org/apache/distributedlog/impl/TestZKLogSegmentMetadataStore.java   | 2 +-
 .../java/org/apache/distributedlog/impl/TestZKNamespaceWatcher.java     | 2 +-
 .../distributedlog/impl/federated/TestFederatedZKLogMetadataStore.java  | 2 +-
 .../distributedlog/impl/logsegment/TestBKLogSegmentEntryReader.java     | 2 +-
 .../distributedlog/impl/metadata/TestZKLogStreamMetadataStore.java      | 2 +-
 .../distributedlog/impl/metadata/TestZKLogStreamMetadataStoreUtils.java | 2 +-
 .../org/apache/distributedlog/impl/metadata/TestZkMetadataResolver.java | 2 +-
 .../test/java/org/apache/distributedlog/limiter/TestRequestLimiter.java | 2 +-
 .../test/java/org/apache/distributedlog/lock/TestDistributedLock.java   | 2 +-
 .../src/test/java/org/apache/distributedlog/lock/TestZKSessionLock.java | 2 +-
 .../apache/distributedlog/logsegment/TestPerStreamLogSegmentCache.java  | 2 +-
 .../java/org/apache/distributedlog/logsegment/TestRollingPolicy.java    | 2 +-
 .../test/java/org/apache/distributedlog/metadata/TestDLMetadata.java    | 2 +-
 .../test/java/org/apache/distributedlog/metadata/TestLogMetadata.java   | 2 +-
 .../distributedlog/metadata/TestLogSegmentMetadataStoreUpdater.java     | 2 +-
 .../java/org/apache/distributedlog/namespace/TestNamespaceBuilder.java  | 2 +-
 .../src/test/java/org/apache/distributedlog/net/TestDNSResolver.java    | 2 +-
 .../core/src/test/java/org/apache/distributedlog/net/TestNetUtils.java  | 2 +-
 .../java/org/apache/distributedlog/selector/TestLogRecordSelectors.java | 2 +-
 .../java/org/apache/distributedlog/tools/TestDistributedLogTool.java    | 2 +-
 .../src/test/java/org/apache/distributedlog/util/TestConfUtils.java     | 2 +-
 .../core/src/test/java/org/apache/distributedlog/util/TestDLUtils.java  | 2 +-
 .../src/test/java/org/apache/distributedlog/util/TestPermitManager.java | 2 +-
 .../src/test/java/org/apache/distributedlog/util/TestTimeSequencer.java | 2 +-
 .../core/src/test/java/org/apache/distributedlog/util/TestUtils.java    | 2 +-
 .../src/test/java/org/apache/distributedlog/zk/TestZKTransaction.java   | 2 +-
 .../test/java/org/apache/distributedlog/zk/TestZKVersionedSetOp.java    | 2 +-
 .../test/java/org/apache/distributedlog/zk/TestZKWatcherManager.java    | 2 +-
 .../protocol/src/main/java/org/apache/distributedlog/DLSN.java          | 2 +-
 .../main/java/org/apache/distributedlog/EnvelopedRecordSetReader.java   | 2 +-
 .../main/java/org/apache/distributedlog/EnvelopedRecordSetWriter.java   | 2 +-
 .../protocol/src/main/java/org/apache/distributedlog/LogRecord.java     | 2 +-
 .../protocol/src/main/java/org/apache/distributedlog/LogRecordSet.java  | 2 +-
 .../src/main/java/org/apache/distributedlog/LogRecordSetBuffer.java     | 2 +-
 .../src/main/java/org/apache/distributedlog/LogRecordWithDLSN.java      | 2 +-
 .../protocol/src/main/java/org/apache/distributedlog/RecordStream.java  | 2 +-
 .../org/apache/distributedlog/exceptions/AlreadyClosedException.java    | 2 +-
 .../distributedlog/exceptions/AlreadyTruncatedTransactionException.java | 2 +-
 .../java/org/apache/distributedlog/exceptions/BKTransmitException.java  | 2 +-
 .../org/apache/distributedlog/exceptions/ChecksumFailedException.java   | 2 +-
 .../org/apache/distributedlog/exceptions/DLClientClosedException.java   | 2 +-
 .../src/main/java/org/apache/distributedlog/exceptions/DLException.java | 2 +-
 .../org/apache/distributedlog/exceptions/DLIllegalStateException.java   | 2 +-
 .../org/apache/distributedlog/exceptions/DLInterruptedException.java    | 2 +-
 .../org/apache/distributedlog/exceptions/EndOfLogSegmentException.java  | 2 +-
 .../java/org/apache/distributedlog/exceptions/EndOfStreamException.java | 2 +-
 .../main/java/org/apache/distributedlog/exceptions/FlushException.java  | 2 +-
 .../java/org/apache/distributedlog/exceptions/IdleReaderException.java  | 2 +-
 .../org/apache/distributedlog/exceptions/InternalServerException.java   | 2 +-
 .../distributedlog/exceptions/InvalidEnvelopedEntryException.java       | 2 +-
 .../apache/distributedlog/exceptions/InvalidStreamNameException.java    | 2 +-
 .../org/apache/distributedlog/exceptions/LockCancelledException.java    | 2 +-
 .../java/org/apache/distributedlog/exceptions/LockingException.java     | 2 +-
 .../java/org/apache/distributedlog/exceptions/LogEmptyException.java    | 2 +-
 .../java/org/apache/distributedlog/exceptions/LogExistsException.java   | 2 +-
 .../java/org/apache/distributedlog/exceptions/LogNotFoundException.java | 2 +-
 .../java/org/apache/distributedlog/exceptions/LogReadException.java     | 2 +-
 .../org/apache/distributedlog/exceptions/LogRecordTooLongException.java | 2 +-
 .../distributedlog/exceptions/LogSegmentIsTruncatedException.java       | 2 +-
 .../apache/distributedlog/exceptions/LogSegmentNotFoundException.java   | 2 +-
 .../java/org/apache/distributedlog/exceptions/MetadataException.java    | 2 +-
 .../apache/distributedlog/exceptions/NotYetImplementedException.java    | 2 +-
 .../org/apache/distributedlog/exceptions/OverCapacityException.java     | 2 +-
 .../distributedlog/exceptions/OwnershipAcquireFailedException.java      | 2 +-
 .../org/apache/distributedlog/exceptions/ReadCancelledException.java    | 2 +-
 .../apache/distributedlog/exceptions/RegionUnavailableException.java    | 2 +-
 .../org/apache/distributedlog/exceptions/RequestDeniedException.java    | 2 +-
 .../org/apache/distributedlog/exceptions/RetryableReadException.java    | 2 +-
 .../apache/distributedlog/exceptions/ServiceUnavailableException.java   | 2 +-
 .../src/main/java/org/apache/distributedlog/exceptions/StatusCode.java  | 2 +-
 .../org/apache/distributedlog/exceptions/StreamNotReadyException.java   | 2 +-
 .../apache/distributedlog/exceptions/StreamUnavailableException.java    | 2 +-
 .../org/apache/distributedlog/exceptions/TooManyStreamsException.java   | 2 +-
 .../distributedlog/exceptions/TransactionIdOutOfOrderException.java     | 2 +-
 .../java/org/apache/distributedlog/exceptions/UnexpectedException.java  | 2 +-
 .../distributedlog/exceptions/UnsupportedMetadataVersionException.java  | 2 +-
 .../org/apache/distributedlog/exceptions/WriteCancelledException.java   | 2 +-
 .../main/java/org/apache/distributedlog/exceptions/WriteException.java  | 2 +-
 .../main/java/org/apache/distributedlog/exceptions/package-info.java    | 2 +-
 .../protocol/src/main/java/org/apache/distributedlog/package-info.java  | 2 +-
 .../protocol/src/test/java/org/apache/distributedlog/TestDLSN.java      | 2 +-
 .../src/test/java/org/apache/distributedlog/TestLogRecordSet.java       | 2 +-
 stream/proto/src/main/proto/cluster.proto                               | 2 +-
 stream/proto/src/main/proto/common.proto                                | 2 +-
 stream/proto/src/main/proto/kv.proto                                    | 2 +-
 stream/proto/src/main/proto/kv_rpc.proto                                | 2 +-
 stream/proto/src/main/proto/kv_store.proto                              | 2 +-
 stream/proto/src/main/proto/storage.proto                               | 2 +-
 stream/proto/src/main/proto/stream.proto                                | 2 +-
 .../src/main/java/org/apache/bookkeeper/statelib/impl/Bytes.java        | 2 +-
 stream/statelib/src/main/proto/kv.proto                                 | 2 +-
 stream/tests-common/src/main/proto/rpc.proto                            | 2 +-
 .../src/test/java/org/apache/bookkeeper/tls/TestBCNonFips.java          | 2 +-
 583 files changed, 583 insertions(+), 583 deletions(-)

diff --git a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/ByteBufAllocatorBuilder.java b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/ByteBufAllocatorBuilder.java
index 33c0f7d5d9..3e36a23d17 100644
--- a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/ByteBufAllocatorBuilder.java
+++ b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/ByteBufAllocatorBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/ByteBufAllocatorWithOomHandler.java b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/ByteBufAllocatorWithOomHandler.java
index b3cd66aa79..209386d16d 100644
--- a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/ByteBufAllocatorWithOomHandler.java
+++ b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/ByteBufAllocatorWithOomHandler.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/LeakDetectionPolicy.java b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/LeakDetectionPolicy.java
index 476684778a..f5c99a7e03 100644
--- a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/LeakDetectionPolicy.java
+++ b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/LeakDetectionPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/OutOfMemoryPolicy.java b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/OutOfMemoryPolicy.java
index ff72050709..d566ca8b87 100644
--- a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/OutOfMemoryPolicy.java
+++ b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/OutOfMemoryPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/PoolingPolicy.java b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/PoolingPolicy.java
index 352a55ed1e..40917b42a1 100644
--- a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/PoolingPolicy.java
+++ b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/PoolingPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/impl/ByteBufAllocatorBuilderImpl.java b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/impl/ByteBufAllocatorBuilderImpl.java
index 66a4beab77..69c57232af 100644
--- a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/impl/ByteBufAllocatorBuilderImpl.java
+++ b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/impl/ByteBufAllocatorBuilderImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/impl/ByteBufAllocatorImpl.java b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/impl/ByteBufAllocatorImpl.java
index 02afbaa407..87582cca92 100644
--- a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/impl/ByteBufAllocatorImpl.java
+++ b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/impl/ByteBufAllocatorImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/impl/package-info.java b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/impl/package-info.java
index 10133096cc..74564caeb0 100644
--- a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/impl/package-info.java
+++ b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/impl/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/package-info.java b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/package-info.java
index 512911402d..d7529ef7b9 100644
--- a/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/package-info.java
+++ b/bookkeeper-common-allocator/src/main/java/org/apache/bookkeeper/common/allocator/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common-allocator/src/test/java/org/apache/bookkeeper/common/allocator/impl/ByteBufAllocatorBuilderTest.java b/bookkeeper-common-allocator/src/test/java/org/apache/bookkeeper/common/allocator/impl/ByteBufAllocatorBuilderTest.java
index 89a9f6ce2c..22918890cf 100644
--- a/bookkeeper-common-allocator/src/test/java/org/apache/bookkeeper/common/allocator/impl/ByteBufAllocatorBuilderTest.java
+++ b/bookkeeper-common-allocator/src/test/java/org/apache/bookkeeper/common/allocator/impl/ByteBufAllocatorBuilderTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/conf/package-info.java b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/conf/package-info.java
index ba4d756491..aa2e5eaa67 100644
--- a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/conf/package-info.java
+++ b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/conf/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/stats/OpStatsListener.java b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/stats/OpStatsListener.java
index ca6eb74c4b..3e8cd60205 100644
--- a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/stats/OpStatsListener.java
+++ b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/stats/OpStatsListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/stats/package-info.java b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/stats/package-info.java
index f211381595..0e2c831c41 100644
--- a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/stats/package-info.java
+++ b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/stats/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/BoundedExecutorService.java b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/BoundedExecutorService.java
index d5f50a2934..e7d9303830 100644
--- a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/BoundedExecutorService.java
+++ b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/BoundedExecutorService.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/BoundedScheduledExecutorService.java b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/BoundedScheduledExecutorService.java
index 54025f21af..bc30c18a53 100644
--- a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/BoundedScheduledExecutorService.java
+++ b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/BoundedScheduledExecutorService.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/ExceptionMessageHelper.java b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/ExceptionMessageHelper.java
index 9fa925d803..f5facdca05 100644
--- a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/ExceptionMessageHelper.java
+++ b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/ExceptionMessageHelper.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/MemoryLimitController.java b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/MemoryLimitController.java
index 7fddfd7876..8a67072c5a 100644
--- a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/MemoryLimitController.java
+++ b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/MemoryLimitController.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/OrderedExecutor.java b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/OrderedExecutor.java
index 6c6c3e57af..982a5d4951 100644
--- a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/OrderedExecutor.java
+++ b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/OrderedExecutor.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/SingleThreadSafeScheduledExecutorService.java b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/SingleThreadSafeScheduledExecutorService.java
index 4bf39a95ea..d41f2411d3 100644
--- a/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/SingleThreadSafeScheduledExecutorService.java
+++ b/bookkeeper-common/src/main/java/org/apache/bookkeeper/common/util/SingleThreadSafeScheduledExecutorService.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common/src/main/java/org/apache/bookkeeper/util/MathUtils.java b/bookkeeper-common/src/main/java/org/apache/bookkeeper/util/MathUtils.java
index 0124b19335..69dbd7b8ea 100644
--- a/bookkeeper-common/src/main/java/org/apache/bookkeeper/util/MathUtils.java
+++ b/bookkeeper-common/src/main/java/org/apache/bookkeeper/util/MathUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common/src/main/java/org/apache/bookkeeper/util/package-info.java b/bookkeeper-common/src/main/java/org/apache/bookkeeper/util/package-info.java
index 28180d1595..41d907c4f1 100644
--- a/bookkeeper-common/src/main/java/org/apache/bookkeeper/util/package-info.java
+++ b/bookkeeper-common/src/main/java/org/apache/bookkeeper/util/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-common/src/test/java/org/apache/bookkeeper/common/util/MemoryLimitControllerTest.java b/bookkeeper-common/src/test/java/org/apache/bookkeeper/common/util/MemoryLimitControllerTest.java
index ffd056c569..2d81f62f92 100644
--- a/bookkeeper-common/src/test/java/org/apache/bookkeeper/common/util/MemoryLimitControllerTest.java
+++ b/bookkeeper-common/src/test/java/org/apache/bookkeeper/common/util/MemoryLimitControllerTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-proto/src/main/proto/DataFormats.proto b/bookkeeper-proto/src/main/proto/DataFormats.proto
index f5cfb312a4..21ffda8415 100644
--- a/bookkeeper-proto/src/main/proto/DataFormats.proto
+++ b/bookkeeper-proto/src/main/proto/DataFormats.proto
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
diff --git a/bookkeeper-proto/src/main/proto/DbLedgerStorageDataFormats.proto b/bookkeeper-proto/src/main/proto/DbLedgerStorageDataFormats.proto
index 6df357d735..6940a8a222 100644
--- a/bookkeeper-proto/src/main/proto/DbLedgerStorageDataFormats.proto
+++ b/bookkeeper-proto/src/main/proto/DbLedgerStorageDataFormats.proto
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
  * this work for additional information regarding copyright ownership.
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/auth/AuthCallbacks.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/auth/AuthCallbacks.java
index 74134b5ff6..a8107d1186 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/auth/AuthCallbacks.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/auth/AuthCallbacks.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieCriticalThread.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieCriticalThread.java
index 53116611c9..31712a60d7 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieCriticalThread.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieCriticalThread.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieFileChannel.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieFileChannel.java
index 8bcde418dc..3bd04cbe35 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieFileChannel.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieFileChannel.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieResources.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieResources.java
index e381c5a65c..c9b71b9968 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieResources.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieResources.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieShell.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieShell.java
index 5d0798351d..f3aaa13027 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieShell.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieShell.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieStatus.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieStatus.java
index a9545cca2d..7b2d0aad99 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieStatus.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieStatus.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieThread.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieThread.java
index 745fa6f1ee..e35db7b68e 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieThread.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BookieThread.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BufferedChannelBase.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BufferedChannelBase.java
index c982ba0866..e52fc4f0c1 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BufferedChannelBase.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/BufferedChannelBase.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/CookieValidation.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/CookieValidation.java
index 06a7026c95..9b4892b5b4 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/CookieValidation.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/CookieValidation.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/FileChannelProvider.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/FileChannelProvider.java
index 85095e1371..47ea110749 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/FileChannelProvider.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/FileChannelProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/LegacyCookieValidation.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/LegacyCookieValidation.java
index 5cc6960364..2a9744d682 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/LegacyCookieValidation.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/bookie/LegacyCookieValidation.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/AsyncCallback.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/AsyncCallback.java
index a742c2db51..715d788ddc 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/AsyncCallback.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/AsyncCallback.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieAddressResolverDisabled.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieAddressResolverDisabled.java
index a4afee6a8e..7fb7e82d75 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieAddressResolverDisabled.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieAddressResolverDisabled.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieInfoReader.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieInfoReader.java
index 345a47aefd..ea6dea0904 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieInfoReader.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieInfoReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieWatcher.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieWatcher.java
index d59231aa07..bfee656e2c 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieWatcher.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieWatcher.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieWatcherImpl.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieWatcherImpl.java
index 652fbcc773..978842b114 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieWatcherImpl.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookieWatcherImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookiesListener.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookiesListener.java
index f4607318e4..7b7dd9c673 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookiesListener.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/BookiesListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/DefaultBookieAddressResolver.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/DefaultBookieAddressResolver.java
index 334216c9ea..08016bdd82 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/DefaultBookieAddressResolver.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/DefaultBookieAddressResolver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/DistributionSchedule.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/DistributionSchedule.java
index 34b8fbb392..ea9017467f 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/DistributionSchedule.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/DistributionSchedule.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ForceLedgerOp.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ForceLedgerOp.java
index b4e4c35eb1..b96fa095dd 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ForceLedgerOp.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ForceLedgerOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerChecker.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerChecker.java
index f9d33b8ce8..a5cf3eec9a 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerChecker.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerChecker.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerFragment.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerFragment.java
index 2dffa10f83..6a09922f67 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerFragment.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerFragment.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerFragmentReplicator.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerFragmentReplicator.java
index 82daf39fc3..877a3ac300 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerFragmentReplicator.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerFragmentReplicator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerMetadataBuilder.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerMetadataBuilder.java
index 5eca19a02e..eaa2efa875 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerMetadataBuilder.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerMetadataBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerMetadataImpl.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerMetadataImpl.java
index 22f7c045a0..14a17bb5fd 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerMetadataImpl.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerMetadataImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerMetadataUtils.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerMetadataUtils.java
index 0c9b6aa71a..ab26be7d65 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerMetadataUtils.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerMetadataUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerRecoveryOp.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerRecoveryOp.java
index e27848bb17..fe697ef4e0 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerRecoveryOp.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/LedgerRecoveryOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/MetadataUpdateLoop.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/MetadataUpdateLoop.java
index 86a9e23f79..83c2b4ada5 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/MetadataUpdateLoop.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/MetadataUpdateLoop.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/PendingAddOp.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/PendingAddOp.java
index 3ed78f6305..d0ff59e45c 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/PendingAddOp.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/PendingAddOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/PendingReadLacOp.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/PendingReadLacOp.java
index c14abe4c8b..07687bfcce 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/PendingReadLacOp.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/PendingReadLacOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/PendingWriteLacOp.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/PendingWriteLacOp.java
index ee3b92fa2a..f34c9f04dc 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/PendingWriteLacOp.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/PendingWriteLacOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ReadLastConfirmedOp.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ReadLastConfirmedOp.java
index ba9fa52f23..4e30c7231e 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ReadLastConfirmedOp.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ReadLastConfirmedOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/RoundRobinDistributionSchedule.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/RoundRobinDistributionSchedule.java
index fbe702a303..81a3550071 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/RoundRobinDistributionSchedule.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/RoundRobinDistributionSchedule.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/TryReadLastConfirmedOp.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/TryReadLastConfirmedOp.java
index 99365ce915..fb01843e64 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/TryReadLastConfirmedOp.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/TryReadLastConfirmedOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/UpdateLedgerOp.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/UpdateLedgerOp.java
index a02ffd602f..bcdb20464a 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/UpdateLedgerOp.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/UpdateLedgerOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ZoneawareEnsemblePlacementPolicy.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ZoneawareEnsemblePlacementPolicy.java
index fabff5a484..cf36c7d83f 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ZoneawareEnsemblePlacementPolicy.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ZoneawareEnsemblePlacementPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ZoneawareEnsemblePlacementPolicyImpl.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ZoneawareEnsemblePlacementPolicyImpl.java
index 11ba6566e7..598b4a63a0 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ZoneawareEnsemblePlacementPolicyImpl.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/ZoneawareEnsemblePlacementPolicyImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/api/LedgerEntries.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/api/LedgerEntries.java
index 141aa6c8c7..621ffb894b 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/api/LedgerEntries.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/client/api/LedgerEntries.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/conf/AbstractConfiguration.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/conf/AbstractConfiguration.java
index 4a87f7a7a4..21bde894a3 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/conf/AbstractConfiguration.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/conf/AbstractConfiguration.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/conf/ClientConfiguration.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/conf/ClientConfiguration.java
index fb9b3d76d7..8aaa8bbff4 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/conf/ClientConfiguration.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/conf/ClientConfiguration.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/conf/ServerConfiguration.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/conf/ServerConfiguration.java
index 1da07d526f..ca9b0ce46a 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/conf/ServerConfiguration.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/conf/ServerConfiguration.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/AbstractHierarchicalLedgerManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/AbstractHierarchicalLedgerManager.java
index 6e0820b669..939870314d 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/AbstractHierarchicalLedgerManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/AbstractHierarchicalLedgerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/AbstractZkLedgerManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/AbstractZkLedgerManager.java
index 929ea3c47d..102c7d7792 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/AbstractZkLedgerManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/AbstractZkLedgerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/AbstractZkLedgerManagerFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/AbstractZkLedgerManagerFactory.java
index 7167dbd414..59fd561efc 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/AbstractZkLedgerManagerFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/AbstractZkLedgerManagerFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/CleanupLedgerManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/CleanupLedgerManager.java
index e1a7961cd3..f9c3a00d68 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/CleanupLedgerManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/CleanupLedgerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/FlatLedgerManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/FlatLedgerManager.java
index 0d29f4f14c..a40a775ed4 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/FlatLedgerManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/FlatLedgerManager.java
@@ -1,6 +1,6 @@
 package org.apache.bookkeeper.meta;
 
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/FlatLedgerManagerFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/FlatLedgerManagerFactory.java
index 80059a53b5..acd23f4ae3 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/FlatLedgerManagerFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/FlatLedgerManagerFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/HierarchicalLedgerManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/HierarchicalLedgerManager.java
index edf7c5c911..d5c0fa1ff9 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/HierarchicalLedgerManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/HierarchicalLedgerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/HierarchicalLedgerManagerFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/HierarchicalLedgerManagerFactory.java
index e52b795ec3..f28763f45f 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/HierarchicalLedgerManagerFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/HierarchicalLedgerManagerFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerAuditorManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerAuditorManager.java
index b1b2fa003f..492433ed1b 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerAuditorManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerAuditorManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerIdGenerator.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerIdGenerator.java
index 70f605a265..32298f57f7 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerIdGenerator.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerIdGenerator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerLayout.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerLayout.java
index 763a39ae83..06b2998d94 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerLayout.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerLayout.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerManager.java
index 20d61066cd..2f08c2e5b7 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerManagerFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerManagerFactory.java
index 3d2355f87a..f1244703f8 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerManagerFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerManagerFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerMetadataSerDe.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerMetadataSerDe.java
index 06f4ec818c..5aa0dd7c33 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerMetadataSerDe.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerMetadataSerDe.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerUnderreplicationManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerUnderreplicationManager.java
index 302862649a..3cd1ceb4b1 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerUnderreplicationManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LedgerUnderreplicationManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LegacyHierarchicalLedgerManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LegacyHierarchicalLedgerManager.java
index e092e44e11..52bd458881 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LegacyHierarchicalLedgerManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LegacyHierarchicalLedgerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LegacyHierarchicalLedgerManagerFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LegacyHierarchicalLedgerManagerFactory.java
index 9bd183a863..1c4ec6021f 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LegacyHierarchicalLedgerManagerFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LegacyHierarchicalLedgerManagerFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LongHierarchicalLedgerManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LongHierarchicalLedgerManager.java
index c724e3e683..ca9216d8ba 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LongHierarchicalLedgerManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LongHierarchicalLedgerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LongHierarchicalLedgerManagerFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LongHierarchicalLedgerManagerFactory.java
index 93ad9ddc68..a697862866 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LongHierarchicalLedgerManagerFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LongHierarchicalLedgerManagerFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LongZkLedgerIdGenerator.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LongZkLedgerIdGenerator.java
index afc3e7e2cf..c42764a0f6 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LongZkLedgerIdGenerator.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/LongZkLedgerIdGenerator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/MSLedgerManagerFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/MSLedgerManagerFactory.java
index e8dfdb08f3..fa4776bd28 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/MSLedgerManagerFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/MSLedgerManagerFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/NullMetadataBookieDriver.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/NullMetadataBookieDriver.java
index 30382e35ee..7d2d84381d 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/NullMetadataBookieDriver.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/NullMetadataBookieDriver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/UnderreplicatedLedger.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/UnderreplicatedLedger.java
index 6ad3036de5..81c92d0352 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/UnderreplicatedLedger.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/UnderreplicatedLedger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/ZkLedgerAuditorManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/ZkLedgerAuditorManager.java
index e6cb8485a0..4f52245514 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/ZkLedgerAuditorManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/ZkLedgerAuditorManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/ZkLedgerIdGenerator.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/ZkLedgerIdGenerator.java
index 3052de7d3b..489be4742b 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/ZkLedgerIdGenerator.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/ZkLedgerIdGenerator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/ZkLedgerUnderreplicationManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/ZkLedgerUnderreplicationManager.java
index f5440f2f81..8587ac0ca0 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/ZkLedgerUnderreplicationManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/meta/ZkLedgerUnderreplicationManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/InMemoryMetaStore.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/InMemoryMetaStore.java
index 95b0989634..90cb450181 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/InMemoryMetaStore.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/InMemoryMetaStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/InMemoryMetastoreCursor.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/InMemoryMetastoreCursor.java
index 181dd46b20..98410d2354 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/InMemoryMetastoreCursor.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/InMemoryMetastoreCursor.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/InMemoryMetastoreTable.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/InMemoryMetastoreTable.java
index 3b4e5e5d4b..6b1deee915 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/InMemoryMetastoreTable.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/InMemoryMetastoreTable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MSException.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MSException.java
index 6d16c1f356..3fbcf538d9 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MSException.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MSException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MSWatchedEvent.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MSWatchedEvent.java
index 08c1721433..84d2e92ab3 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MSWatchedEvent.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MSWatchedEvent.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetaStore.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetaStore.java
index 62d7a32395..8d7c5d4a7c 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetaStore.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetaStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreCallback.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreCallback.java
index b25311a663..f1679ed531 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreCallback.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreCallback.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreCursor.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreCursor.java
index abd1cd4782..a2a2211a23 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreCursor.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreCursor.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreException.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreException.java
index f66fe00e84..f1f8d04d30 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreException.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreFactory.java
index 847d209152..30a36c7ac7 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreScannableTable.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreScannableTable.java
index 1e073d4f0f..bc92a7938a 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreScannableTable.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreScannableTable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreTable.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreTable.java
index d302b681e7..562fcda1aa 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreTable.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreTable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreTableItem.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreTableItem.java
index 349548b187..0155bf4812 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreTableItem.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreTableItem.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreUtils.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreUtils.java
index a1678cba83..1f326b1eec 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreUtils.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreWatcher.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreWatcher.java
index b751dfa7fc..ebd0dd3be6 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreWatcher.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/MetastoreWatcher.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/Value.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/Value.java
index 911059af4c..3936d77bd8 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/Value.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/metastore/Value.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/AbstractDNSToSwitchMapping.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/AbstractDNSToSwitchMapping.java
index 7a87ae75dd..3060b86bbb 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/AbstractDNSToSwitchMapping.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/AbstractDNSToSwitchMapping.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/BookieNode.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/BookieNode.java
index b22ae5f61a..abf22c04e3 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/BookieNode.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/BookieNode.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/CachedDNSToSwitchMapping.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/CachedDNSToSwitchMapping.java
index ac9aa32788..ae383d1525 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/CachedDNSToSwitchMapping.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/CachedDNSToSwitchMapping.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/DNS.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/DNS.java
index 633ed9448e..68ff662126 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/DNS.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/DNS.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/DNSToSwitchMapping.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/DNSToSwitchMapping.java
index 2ffcd0c5ec..0083f8d63a 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/DNSToSwitchMapping.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/DNSToSwitchMapping.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NetUtils.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NetUtils.java
index 72aefc6fd2..64e3d810d0 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NetUtils.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NetUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NetworkTopologyImpl.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NetworkTopologyImpl.java
index f847eac999..8397437492 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NetworkTopologyImpl.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NetworkTopologyImpl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/Node.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/Node.java
index 86c86af4a2..e160ef8fb0 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/Node.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/Node.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NodeBase.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NodeBase.java
index 3373b2e02c..46442f50c1 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NodeBase.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/NodeBase.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/ScriptBasedMapping.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/ScriptBasedMapping.java
index cf3e6c24a7..c4787119af 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/ScriptBasedMapping.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/net/ScriptBasedMapping.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/LongPollReadEntryProcessorV3.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/LongPollReadEntryProcessorV3.java
index 7c18e7ab17..f61a2688ba 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/LongPollReadEntryProcessorV3.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/LongPollReadEntryProcessorV3.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/PacketProcessorBase.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/PacketProcessorBase.java
index 3d42ee70a7..633a8ef833 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/PacketProcessorBase.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/PacketProcessorBase.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/PerChannelBookieClient.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/PerChannelBookieClient.java
index c4643faa56..888077fe80 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/PerChannelBookieClient.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/PerChannelBookieClient.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/ReadEntryProcessor.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/ReadEntryProcessor.java
index 3373bf8ffd..71ee51f3fa 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/ReadEntryProcessor.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/ReadEntryProcessor.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/ReadEntryProcessorV3.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/ReadEntryProcessorV3.java
index 3f54b588ef..4672d592d8 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/ReadEntryProcessorV3.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/ReadEntryProcessorV3.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/RequestUtils.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/RequestUtils.java
index d384c817a4..9b8533da0c 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/RequestUtils.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/RequestUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/WriteEntryProcessor.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/WriteEntryProcessor.java
index 881baf83ac..3877dccf10 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/WriteEntryProcessor.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/WriteEntryProcessor.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/checksum/DigestManager.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/checksum/DigestManager.java
index 96d1405715..7b0f57a945 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/checksum/DigestManager.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/proto/checksum/DigestManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/replication/BookieLedgerIndexer.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/replication/BookieLedgerIndexer.java
index 69438ccfcd..38cc79e56e 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/replication/BookieLedgerIndexer.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/replication/BookieLedgerIndexer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/replication/ReplicationException.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/replication/ReplicationException.java
index 34479fbf11..1c1bcde698 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/replication/ReplicationException.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/replication/ReplicationException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/replication/ReplicationWorker.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/replication/ReplicationWorker.java
index 28062ea36c..a153652db5 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/replication/ReplicationWorker.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/replication/ReplicationWorker.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/BookieAuthZFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/BookieAuthZFactory.java
index 52f6257454..5cef655c50 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/BookieAuthZFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/BookieAuthZFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/FileModifiedTimeUpdater.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/FileModifiedTimeUpdater.java
index 75ae828c78..e41b507a58 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/FileModifiedTimeUpdater.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/FileModifiedTimeUpdater.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/SecurityException.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/SecurityException.java
index 67fa1980a7..d4c3ea9725 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/SecurityException.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/SecurityException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/SecurityHandlerFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/SecurityHandlerFactory.java
index 01a4f31967..a545b7ef04 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/SecurityHandlerFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/SecurityHandlerFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/SecurityProviderFactoryFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/SecurityProviderFactoryFactory.java
index 6eb2c94158..63bc87e2a4 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/SecurityProviderFactoryFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/SecurityProviderFactoryFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/TLSContextFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/TLSContextFactory.java
index 3eb23196a4..03f9951d8c 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/TLSContextFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tls/TLSContextFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tools/cli/commands/autorecovery/package-info.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tools/cli/commands/autorecovery/package-info.java
index acfe982e30..1f696ea779 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tools/cli/commands/autorecovery/package-info.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tools/cli/commands/autorecovery/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tools/cli/commands/bookie/ListActiveLedgersCommand.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tools/cli/commands/bookie/ListActiveLedgersCommand.java
index fbe230cbcd..88c29d52b5 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tools/cli/commands/bookie/ListActiveLedgersCommand.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tools/cli/commands/bookie/ListActiveLedgersCommand.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tools/cli/commands/health/package-info.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tools/cli/commands/health/package-info.java
index 8966724d87..b99bc018fe 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/tools/cli/commands/health/package-info.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/tools/cli/commands/health/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/AvailabilityOfEntriesOfLedger.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/AvailabilityOfEntriesOfLedger.java
index 027ed1f538..24361cede9 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/AvailabilityOfEntriesOfLedger.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/AvailabilityOfEntriesOfLedger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/BookKeeperConstants.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/BookKeeperConstants.java
index d928aac2fc..107708092f 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/BookKeeperConstants.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/BookKeeperConstants.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/CertUtils.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/CertUtils.java
index 8d103ab2c7..ffdcbaf947 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/CertUtils.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/CertUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/DaemonThreadFactory.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/DaemonThreadFactory.java
index 4c6d445a23..feddf2a630 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/DaemonThreadFactory.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/DaemonThreadFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/DiskChecker.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/DiskChecker.java
index 52e99f3e27..db8d350c97 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/DiskChecker.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/DiskChecker.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/EventLoopUtil.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/EventLoopUtil.java
index 74e59febc2..47eaf5c4c5 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/EventLoopUtil.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/EventLoopUtil.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/HardLink.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/HardLink.java
index ea92867b3e..d3e72b8aad 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/HardLink.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/HardLink.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/LocalBookKeeper.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/LocalBookKeeper.java
index 28194871ba..dff6d1b8ba 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/LocalBookKeeper.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/LocalBookKeeper.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/NativeIO.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/NativeIO.java
index 788d9279af..d509053aa7 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/NativeIO.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/NativeIO.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/OrderedGenericCallback.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/OrderedGenericCallback.java
index 3bdbef1c99..3d12848001 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/OrderedGenericCallback.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/OrderedGenericCallback.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/SafeRunnable.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/SafeRunnable.java
index a03f5fc14c..b4ce368feb 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/SafeRunnable.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/SafeRunnable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/Shell.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/Shell.java
index 16d597eeb1..7a0c68f627 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/Shell.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/Shell.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/SnapshotMap.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/SnapshotMap.java
index 8902d069ea..8afba5bd59 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/SnapshotMap.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/SnapshotMap.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/StringUtils.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/StringUtils.java
index c5fb415b91..1a752003ef 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/StringUtils.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/StringUtils.java
@@ -1,6 +1,6 @@
 package org.apache.bookkeeper.util;
 
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/Tool.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/Tool.java
index 8a60af039a..8bf25e5132 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/Tool.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/util/Tool.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/verifier/BookkeeperVerifier.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/verifier/BookkeeperVerifier.java
index 0869a9da4b..927504061d 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/verifier/BookkeeperVerifier.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/verifier/BookkeeperVerifier.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/main/java/org/apache/bookkeeper/versioning/Versioned.java b/bookkeeper-server/src/main/java/org/apache/bookkeeper/versioning/Versioned.java
index f6926248d0..85e695cd53 100644
--- a/bookkeeper-server/src/main/java/org/apache/bookkeeper/versioning/Versioned.java
+++ b/bookkeeper-server/src/main/java/org/apache/bookkeeper/versioning/Versioned.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/bookie/BookieThreadTest.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/bookie/BookieThreadTest.java
index 0d51559d75..1f237f7249 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/bookie/BookieThreadTest.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/bookie/BookieThreadTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/bookie/CreateNewLogTest.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/bookie/CreateNewLogTest.java
index 55e6436227..3155343224 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/bookie/CreateNewLogTest.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/bookie/CreateNewLogTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/bookie/storage/ldb/KeyValueStorageRocksDBTest.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/bookie/storage/ldb/KeyValueStorageRocksDBTest.java
index 4819232810..e7b4824913 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/bookie/storage/ldb/KeyValueStorageRocksDBTest.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/bookie/storage/ldb/KeyValueStorageRocksDBTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/BookieRecoveryUseIOThreadTest.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/BookieRecoveryUseIOThreadTest.java
index a9d7a0ef50..3bf87f4cf1 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/BookieRecoveryUseIOThreadTest.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/BookieRecoveryUseIOThreadTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/ClientUtil.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/ClientUtil.java
index 73433daad4..d24022e504 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/ClientUtil.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/ClientUtil.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/LedgerHandleAdapter.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/LedgerHandleAdapter.java
index ea95b9366e..7d5cad6531 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/LedgerHandleAdapter.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/LedgerHandleAdapter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/ListLedgersTest.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/ListLedgersTest.java
index 9129f7d2a7..8bb23684bc 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/ListLedgersTest.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/ListLedgersTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MetadataUpdateLoopTest.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MetadataUpdateLoopTest.java
index 797f136a7a..5b7db179b1 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MetadataUpdateLoopTest.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MetadataUpdateLoopTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockBookKeeper.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockBookKeeper.java
index 7d3a93f381..b7149b384f 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockBookKeeper.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockBookKeeper.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockBookKeeperTest.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockBookKeeperTest.java
index 672298efdd..a740593471 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockBookKeeperTest.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockBookKeeperTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockBookKeeperTestCase.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockBookKeeperTestCase.java
index 2ee6feb3c8..63255310c3 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockBookKeeperTestCase.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockBookKeeperTestCase.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockLedgerEntry.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockLedgerEntry.java
index f622118a39..ca1a20cca7 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockLedgerEntry.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockLedgerEntry.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockLedgerHandle.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockLedgerHandle.java
index 7e24998ee0..73f9cfa253 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockLedgerHandle.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockLedgerHandle.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockReadHandle.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockReadHandle.java
index 0e3dc8d903..b180aec106 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockReadHandle.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/MockReadHandle.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/TestLedgerFragmentReplication.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/TestLedgerFragmentReplication.java
index 848e6ba144..a010930e06 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/TestLedgerFragmentReplication.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/TestLedgerFragmentReplication.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/TestMaxSizeWorkersQueue.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/TestMaxSizeWorkersQueue.java
index 65a834186b..3487566a87 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/TestMaxSizeWorkersQueue.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/client/TestMaxSizeWorkersQueue.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/MockLedgerManager.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/MockLedgerManager.java
index fbf623ddd0..3704e39e33 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/MockLedgerManager.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/MockLedgerManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/TestLedgerMetadataSerDe.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/TestLedgerMetadataSerDe.java
index 6f4d414756..be2a0f34a8 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/TestLedgerMetadataSerDe.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/TestLedgerMetadataSerDe.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/TestLongZkLedgerIdGenerator.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/TestLongZkLedgerIdGenerator.java
index 5c3ce391c7..b409cc6b2f 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/TestLongZkLedgerIdGenerator.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/TestLongZkLedgerIdGenerator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/TestZkLedgerIdGenerator.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/TestZkLedgerIdGenerator.java
index 4a41736e51..44c739334a 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/TestZkLedgerIdGenerator.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/meta/TestZkLedgerIdGenerator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/metastore/MetastoreScannableTableAsyncToSyncConverter.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/metastore/MetastoreScannableTableAsyncToSyncConverter.java
index 023ca49147..72f20a5391 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/metastore/MetastoreScannableTableAsyncToSyncConverter.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/metastore/MetastoreScannableTableAsyncToSyncConverter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/metastore/MetastoreTableAsyncToSyncConverter.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/metastore/MetastoreTableAsyncToSyncConverter.java
index 1f6ae0021f..aee1b0f83f 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/metastore/MetastoreTableAsyncToSyncConverter.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/metastore/MetastoreTableAsyncToSyncConverter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/metastore/TestMetaStore.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/metastore/TestMetaStore.java
index 9e0fd45a3c..bd89733cec 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/metastore/TestMetaStore.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/metastore/TestMetaStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/proto/BookieBackpressureForV2Test.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/proto/BookieBackpressureForV2Test.java
index 775844d05e..ce8d65fb76 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/proto/BookieBackpressureForV2Test.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/proto/BookieBackpressureForV2Test.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/replication/BookieAutoRecoveryTest.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/replication/BookieAutoRecoveryTest.java
index 328dc97dd4..ccb262ed26 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/replication/BookieAutoRecoveryTest.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/replication/BookieAutoRecoveryTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/replication/BookieLedgerIndexTest.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/replication/BookieLedgerIndexTest.java
index f184912d87..f448391798 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/replication/BookieLedgerIndexTest.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/replication/BookieLedgerIndexTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/replication/TestReplicationWorker.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/replication/TestReplicationWorker.java
index 510d02f8db..9982dd506a 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/replication/TestReplicationWorker.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/replication/TestReplicationWorker.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/sasl/MiniKdc.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/sasl/MiniKdc.java
index f5cb16164e..42b0fd85c1 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/sasl/MiniKdc.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/sasl/MiniKdc.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/tls/TestBookieAuthZFactory.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/tls/TestBookieAuthZFactory.java
index a09a6e8b41..2cd0a80b32 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/tls/TestBookieAuthZFactory.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/tls/TestBookieAuthZFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/tls/TestTLS.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/tls/TestTLS.java
index 2b0ba17a79..b5719deea0 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/tls/TestTLS.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/tls/TestTLS.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/bookkeeper-server/src/test/java/org/apache/bookkeeper/util/TestDiskChecker.java b/bookkeeper-server/src/test/java/org/apache/bookkeeper/util/TestDiskChecker.java
index 58a8236d31..c7d52878a1 100644
--- a/bookkeeper-server/src/test/java/org/apache/bookkeeper/util/TestDiskChecker.java
+++ b/bookkeeper-server/src/test/java/org/apache/bookkeeper/util/TestDiskChecker.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/circe-checksum/src/main/java/com/scurrilous/circe/utils/NativeUtils.java b/circe-checksum/src/main/java/com/scurrilous/circe/utils/NativeUtils.java
index 05ace29580..2932c65000 100644
--- a/circe-checksum/src/main/java/com/scurrilous/circe/utils/NativeUtils.java
+++ b/circe-checksum/src/main/java/com/scurrilous/circe/utils/NativeUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/circe-checksum/src/test/java/com/scurrilous/circe/utils/NativeUtilsTests.java b/circe-checksum/src/test/java/com/scurrilous/circe/utils/NativeUtilsTests.java
index adaf7715d2..17bb45ace2 100644
--- a/circe-checksum/src/test/java/com/scurrilous/circe/utils/NativeUtilsTests.java
+++ b/circe-checksum/src/test/java/com/scurrilous/circe/utils/NativeUtilsTests.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/metadata-drivers/etcd/src/main/java/org/apache/bookkeeper/metadata/etcd/EtcdConstants.java b/metadata-drivers/etcd/src/main/java/org/apache/bookkeeper/metadata/etcd/EtcdConstants.java
index 47558c7466..c9a1dadd23 100644
--- a/metadata-drivers/etcd/src/main/java/org/apache/bookkeeper/metadata/etcd/EtcdConstants.java
+++ b/metadata-drivers/etcd/src/main/java/org/apache/bookkeeper/metadata/etcd/EtcdConstants.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/microbenchmarks/src/main/java/org/apache/bookkeeper/proto/checksum/DigestTypeBenchmark.java b/microbenchmarks/src/main/java/org/apache/bookkeeper/proto/checksum/DigestTypeBenchmark.java
index c709e526ab..b26bf4cdd9 100644
--- a/microbenchmarks/src/main/java/org/apache/bookkeeper/proto/checksum/DigestTypeBenchmark.java
+++ b/microbenchmarks/src/main/java/org/apache/bookkeeper/proto/checksum/DigestTypeBenchmark.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/microbenchmarks/src/main/java/org/apache/bookkeeper/stats/codahale/TimerBenchmark.java b/microbenchmarks/src/main/java/org/apache/bookkeeper/stats/codahale/TimerBenchmark.java
index c6d568fbdc..8c34e91896 100644
--- a/microbenchmarks/src/main/java/org/apache/bookkeeper/stats/codahale/TimerBenchmark.java
+++ b/microbenchmarks/src/main/java/org/apache/bookkeeper/stats/codahale/TimerBenchmark.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/native-io/src/main/java/org/apache/bookkeeper/common/util/nativeio/NativeIO.java b/native-io/src/main/java/org/apache/bookkeeper/common/util/nativeio/NativeIO.java
index 562b957ff4..36bedd050c 100644
--- a/native-io/src/main/java/org/apache/bookkeeper/common/util/nativeio/NativeIO.java
+++ b/native-io/src/main/java/org/apache/bookkeeper/common/util/nativeio/NativeIO.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/native-io/src/main/java/org/apache/bookkeeper/common/util/nativeio/NativeUtils.java b/native-io/src/main/java/org/apache/bookkeeper/common/util/nativeio/NativeUtils.java
index 44d80defea..b3bdf9ab2f 100644
--- a/native-io/src/main/java/org/apache/bookkeeper/common/util/nativeio/NativeUtils.java
+++ b/native-io/src/main/java/org/apache/bookkeeper/common/util/nativeio/NativeUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/AlertStatsLogger.java b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/AlertStatsLogger.java
index f9ffe3578f..9b79449ec4 100644
--- a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/AlertStatsLogger.java
+++ b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/AlertStatsLogger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/CachingStatsLogger.java b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/CachingStatsLogger.java
index 6d6b64adfe..be8ff2ea4e 100644
--- a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/CachingStatsLogger.java
+++ b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/CachingStatsLogger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/CachingStatsProvider.java b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/CachingStatsProvider.java
index e3fa3aa69c..d62084ef03 100644
--- a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/CachingStatsProvider.java
+++ b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/CachingStatsProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/Counter.java b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/Counter.java
index 8f70f44e69..7ba3c51267 100644
--- a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/Counter.java
+++ b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/Counter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/Gauge.java b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/Gauge.java
index 7bcca64abf..fbadda9b06 100644
--- a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/Gauge.java
+++ b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/Gauge.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/NullStatsLogger.java b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/NullStatsLogger.java
index a130b76b67..0a87d8858d 100644
--- a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/NullStatsLogger.java
+++ b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/NullStatsLogger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/NullStatsProvider.java b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/NullStatsProvider.java
index e9c40ca1f0..abc4c31f02 100644
--- a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/NullStatsProvider.java
+++ b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/NullStatsProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/OpStatsData.java b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/OpStatsData.java
index 683386fb97..eb30d7ef40 100644
--- a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/OpStatsData.java
+++ b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/OpStatsData.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/OpStatsLogger.java b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/OpStatsLogger.java
index 3c9c730307..30d7ae09e9 100644
--- a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/OpStatsLogger.java
+++ b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/OpStatsLogger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/StatsLogger.java b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/StatsLogger.java
index 86c569c457..a7a04b6438 100644
--- a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/StatsLogger.java
+++ b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/StatsLogger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/StatsProvider.java b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/StatsProvider.java
index 0d500f1fd4..f16289dca2 100644
--- a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/StatsProvider.java
+++ b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/StatsProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/ThreadRegistry.java b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/ThreadRegistry.java
index db59e03c56..e890660ebb 100644
--- a/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/ThreadRegistry.java
+++ b/stats/bookkeeper-stats-api/src/main/java/org/apache/bookkeeper/stats/ThreadRegistry.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/CodahaleMetricsProvider.java b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/CodahaleMetricsProvider.java
index 8c58c5210b..0beac74d25 100644
--- a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/CodahaleMetricsProvider.java
+++ b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/CodahaleMetricsProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/CodahaleOpStatsLogger.java b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/CodahaleOpStatsLogger.java
index 1e8f868860..e858713196 100644
--- a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/CodahaleOpStatsLogger.java
+++ b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/CodahaleOpStatsLogger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/CodahaleStatsLogger.java b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/CodahaleStatsLogger.java
index 4851362efd..8ed00ac7a8 100644
--- a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/CodahaleStatsLogger.java
+++ b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/CodahaleStatsLogger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastCodahaleMetricsProvider.java b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastCodahaleMetricsProvider.java
index cc5e615211..240f6d8077 100644
--- a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastCodahaleMetricsProvider.java
+++ b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastCodahaleMetricsProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastCodahaleStatsLogger.java b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastCodahaleStatsLogger.java
index 279019c799..ca4a01b153 100644
--- a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastCodahaleStatsLogger.java
+++ b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastCodahaleStatsLogger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastSnapshot.java b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastSnapshot.java
index f6ceb8834d..1637990125 100644
--- a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastSnapshot.java
+++ b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastSnapshot.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastTimer.java b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastTimer.java
index cabb3b8885..2333df2f3f 100644
--- a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastTimer.java
+++ b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/main/java/org/apache/bookkeeper/stats/codahale/FastTimer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/test/java/org/apache/bookkeeper/stats/codahale/CodahaleOpStatsTest.java b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/test/java/org/apache/bookkeeper/stats/codahale/CodahaleOpStatsTest.java
index 3d69ddb9ea..ad4e7de023 100644
--- a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/test/java/org/apache/bookkeeper/stats/codahale/CodahaleOpStatsTest.java
+++ b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/test/java/org/apache/bookkeeper/stats/codahale/CodahaleOpStatsTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/test/java/org/apache/bookkeeper/stats/codahale/FastTimerTest.java b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/test/java/org/apache/bookkeeper/stats/codahale/FastTimerTest.java
index aa6b303fd7..bc95dff074 100644
--- a/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/test/java/org/apache/bookkeeper/stats/codahale/FastTimerTest.java
+++ b/stats/bookkeeper-stats-providers/codahale-metrics-provider/src/test/java/org/apache/bookkeeper/stats/codahale/FastTimerTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/DataSketchesOpStatsLogger.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/DataSketchesOpStatsLogger.java
index 57ae7b3d1c..015c3d3b24 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/DataSketchesOpStatsLogger.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/DataSketchesOpStatsLogger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/LongAdderCounter.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/LongAdderCounter.java
index 687931ef5d..4572ebc692 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/LongAdderCounter.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/LongAdderCounter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusMetricsProvider.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusMetricsProvider.java
index 59b10a9b40..046fdde11a 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusMetricsProvider.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusMetricsProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusServlet.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusServlet.java
index f8ee57e24a..9c4cc776e0 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusServlet.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusServlet.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusStatsLogger.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusStatsLogger.java
index f89377d65b..98f0bd2c91 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusStatsLogger.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusStatsLogger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusTextFormat.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusTextFormat.java
index 32b56c9d43..a3bf919f1f 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusTextFormat.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/PrometheusTextFormat.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/ScopeContext.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/ScopeContext.java
index 48a8d63e7a..53bc368763 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/ScopeContext.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/ScopeContext.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/SimpleGauge.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/SimpleGauge.java
index 1d831cc88f..b67cee36f3 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/SimpleGauge.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/SimpleGauge.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/ThreadScopedDataSketchesStatsLogger.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/ThreadScopedDataSketchesStatsLogger.java
index 704ec4c723..53aca52792 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/ThreadScopedDataSketchesStatsLogger.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/ThreadScopedDataSketchesStatsLogger.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/ThreadScopedLongAdderCounter.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/ThreadScopedLongAdderCounter.java
index ad717e55a5..32fe6c0f2c 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/ThreadScopedLongAdderCounter.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/main/java/org/apache/bookkeeper/stats/prometheus/ThreadScopedLongAdderCounter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/test/java/org/apache/bookkeeper/stats/prometheus/PrometheusTextFormatTest.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/test/java/org/apache/bookkeeper/stats/prometheus/PrometheusTextFormatTest.java
index 2c6d373468..bce5fce480 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/test/java/org/apache/bookkeeper/stats/prometheus/PrometheusTextFormatTest.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/test/java/org/apache/bookkeeper/stats/prometheus/PrometheusTextFormatTest.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/test/java/org/apache/bookkeeper/stats/prometheus/TestPrometheusFormatter.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/test/java/org/apache/bookkeeper/stats/prometheus/TestPrometheusFormatter.java
index 1bba814939..7ef06eb4de 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/test/java/org/apache/bookkeeper/stats/prometheus/TestPrometheusFormatter.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/test/java/org/apache/bookkeeper/stats/prometheus/TestPrometheusFormatter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/test/java/org/apache/bookkeeper/stats/prometheus/TestPrometheusMetricsProvider.java b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/test/java/org/apache/bookkeeper/stats/prometheus/TestPrometheusMetricsProvider.java
index f11518983f..6f1b196283 100644
--- a/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/test/java/org/apache/bookkeeper/stats/prometheus/TestPrometheusMetricsProvider.java
+++ b/stats/bookkeeper-stats-providers/prometheus-metrics-provider/src/test/java/org/apache/bookkeeper/stats/prometheus/TestPrometheusMetricsProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/stream/api/src/main/java/org/apache/bookkeeper/api/kv/package-info.java b/stream/api/src/main/java/org/apache/bookkeeper/api/kv/package-info.java
index 4ede901748..ee651aeb80 100644
--- a/stream/api/src/main/java/org/apache/bookkeeper/api/kv/package-info.java
+++ b/stream/api/src/main/java/org/apache/bookkeeper/api/kv/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/clients/java/all/src/main/java/org/apache/bookkeeper/clients/package-info.java b/stream/clients/java/all/src/main/java/org/apache/bookkeeper/clients/package-info.java
index a155791cc5..374053b13d 100644
--- a/stream/clients/java/all/src/main/java/org/apache/bookkeeper/clients/package-info.java
+++ b/stream/clients/java/all/src/main/java/org/apache/bookkeeper/clients/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/clients/java/base/src/main/java/org/apache/bookkeeper/clients/impl/channel/package-info.java b/stream/clients/java/base/src/main/java/org/apache/bookkeeper/clients/impl/channel/package-info.java
index 6eac9a75be..0124fe5448 100644
--- a/stream/clients/java/base/src/main/java/org/apache/bookkeeper/clients/impl/channel/package-info.java
+++ b/stream/clients/java/base/src/main/java/org/apache/bookkeeper/clients/impl/channel/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/common/src/main/java/org/apache/bookkeeper/common/hash/package-info.java b/stream/common/src/main/java/org/apache/bookkeeper/common/hash/package-info.java
index be43dbc813..c26c1c1357 100644
--- a/stream/common/src/main/java/org/apache/bookkeeper/common/hash/package-info.java
+++ b/stream/common/src/main/java/org/apache/bookkeeper/common/hash/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/common/src/main/java/org/apache/bookkeeper/common/router/AbstractHashRouter.java b/stream/common/src/main/java/org/apache/bookkeeper/common/router/AbstractHashRouter.java
index 5313276f79..b5bad37ef1 100644
--- a/stream/common/src/main/java/org/apache/bookkeeper/common/router/AbstractHashRouter.java
+++ b/stream/common/src/main/java/org/apache/bookkeeper/common/router/AbstractHashRouter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/common/src/main/java/org/apache/bookkeeper/common/router/HashRouter.java b/stream/common/src/main/java/org/apache/bookkeeper/common/router/HashRouter.java
index 94bbb6113c..cd8b68abc8 100644
--- a/stream/common/src/main/java/org/apache/bookkeeper/common/router/HashRouter.java
+++ b/stream/common/src/main/java/org/apache/bookkeeper/common/router/HashRouter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/common/src/main/java/org/apache/bookkeeper/common/router/StringUtf8HashRouter.java b/stream/common/src/main/java/org/apache/bookkeeper/common/router/StringUtf8HashRouter.java
index e665f5d1c1..44351e5298 100644
--- a/stream/common/src/main/java/org/apache/bookkeeper/common/router/StringUtf8HashRouter.java
+++ b/stream/common/src/main/java/org/apache/bookkeeper/common/router/StringUtf8HashRouter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/common/src/main/java/org/apache/bookkeeper/common/router/package-info.java b/stream/common/src/main/java/org/apache/bookkeeper/common/router/package-info.java
index 1612a1cf96..d4de328985 100644
--- a/stream/common/src/main/java/org/apache/bookkeeper/common/router/package-info.java
+++ b/stream/common/src/main/java/org/apache/bookkeeper/common/router/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/common/src/main/java/org/apache/bookkeeper/common/util/Bytes.java b/stream/common/src/main/java/org/apache/bookkeeper/common/util/Bytes.java
index 6b3a940034..af7f5174b8 100644
--- a/stream/common/src/main/java/org/apache/bookkeeper/common/util/Bytes.java
+++ b/stream/common/src/main/java/org/apache/bookkeeper/common/util/Bytes.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/common/src/main/java/org/apache/bookkeeper/common/util/IRevisioned.java b/stream/common/src/main/java/org/apache/bookkeeper/common/util/IRevisioned.java
index 6a25788648..308b292a4b 100644
--- a/stream/common/src/main/java/org/apache/bookkeeper/common/util/IRevisioned.java
+++ b/stream/common/src/main/java/org/apache/bookkeeper/common/util/IRevisioned.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/annotations/DistributedLogAnnotations.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/annotations/DistributedLogAnnotations.java
index c1de7f6a28..1e927630d4 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/annotations/DistributedLogAnnotations.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/annotations/DistributedLogAnnotations.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/annotations/package-info.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/annotations/package-info.java
index a39070006f..6b050197cb 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/annotations/package-info.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/annotations/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/concurrent/AsyncSemaphore.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/concurrent/AsyncSemaphore.java
index 095df411b6..67d6af843c 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/concurrent/AsyncSemaphore.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/concurrent/AsyncSemaphore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/rate/MovingAverageRate.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/rate/MovingAverageRate.java
index f3e8c33904..a1799f471e 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/rate/MovingAverageRate.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/rate/MovingAverageRate.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/rate/MovingAverageRateFactory.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/rate/MovingAverageRateFactory.java
index 790ba0372b..671d6d2acf 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/rate/MovingAverageRateFactory.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/rate/MovingAverageRateFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/rate/SampledMovingAverageRate.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/rate/SampledMovingAverageRate.java
index edbd15efc7..ea4b5a7955 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/rate/SampledMovingAverageRate.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/rate/SampledMovingAverageRate.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/stats/OpStatsListener.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/stats/OpStatsListener.java
index 6a8fd743d2..c8e626299b 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/stats/OpStatsListener.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/stats/OpStatsListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/stats/package-info.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/stats/package-info.java
index 919c459be9..c53b9c2d38 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/stats/package-info.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/stats/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/BitMaskUtils.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/BitMaskUtils.java
index 53f4ab24f5..d305662e4d 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/BitMaskUtils.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/BitMaskUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/MathUtil.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/MathUtil.java
index 38b3ed27f9..38b201ba27 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/MathUtil.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/MathUtil.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/Permit.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/Permit.java
index 24cb63dfd5..77416f2470 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/Permit.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/Permit.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/ReferenceCounted.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/ReferenceCounted.java
index 2df0226645..ab85a6213f 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/ReferenceCounted.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/common/util/ReferenceCounted.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/AsyncCloseable.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/AsyncCloseable.java
index 9e67e53697..d600188b0d 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/AsyncCloseable.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/AsyncCloseable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/AsyncDeleteable.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/AsyncDeleteable.java
index f7c3e3bf87..48975b5fb6 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/AsyncDeleteable.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/AsyncDeleteable.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/CompressionCodec.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/CompressionCodec.java
index f07647e62c..b8dd5c4c5a 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/CompressionCodec.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/CompressionCodec.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/CompressionUtils.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/CompressionUtils.java
index ecbc09dc25..9c8213147f 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/CompressionUtils.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/CompressionUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/IdentityCompressionCodec.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/IdentityCompressionCodec.java
index d082ff8eb8..74b044a488 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/IdentityCompressionCodec.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/IdentityCompressionCodec.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/LZ4CompressionCodec.java b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/LZ4CompressionCodec.java
index 0f6b30a7e0..48439d23a1 100644
--- a/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/LZ4CompressionCodec.java
+++ b/stream/distributedlog/common/src/main/java/org/apache/distributedlog/io/LZ4CompressionCodec.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/bookkeeper/client/BookKeeperAccessor.java b/stream/distributedlog/core/src/main/java/org/apache/bookkeeper/client/BookKeeperAccessor.java
index 2ca0268c3a..b500893825 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/bookkeeper/client/BookKeeperAccessor.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/bookkeeper/client/BookKeeperAccessor.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/bookkeeper/client/LedgerReader.java b/stream/distributedlog/core/src/main/java/org/apache/bookkeeper/client/LedgerReader.java
index 4fc3d05be2..3a3a4c5413 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/bookkeeper/client/LedgerReader.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/bookkeeper/client/LedgerReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/AppendOnlyStreamReader.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/AppendOnlyStreamReader.java
index 74c735bc3a..2663068239 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/AppendOnlyStreamReader.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/AppendOnlyStreamReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/AppendOnlyStreamWriter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/AppendOnlyStreamWriter.java
index d47141070e..eadf83704d 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/AppendOnlyStreamWriter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/AppendOnlyStreamWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/AsyncNotification.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/AsyncNotification.java
index 9746d56878..4d7b04e3e0 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/AsyncNotification.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/AsyncNotification.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKAbstractLogWriter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKAbstractLogWriter.java
index 6f8e0f1c91..b6101ff731 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKAbstractLogWriter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKAbstractLogWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKAsyncLogReader.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKAsyncLogReader.java
index c72ad7d0d6..2e9327be42 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKAsyncLogReader.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKAsyncLogReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKAsyncLogWriter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKAsyncLogWriter.java
index 819a43c15a..31cbab62d3 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKAsyncLogWriter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKAsyncLogWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKDistributedLogManager.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKDistributedLogManager.java
index a99e84479b..3505cbe1a5 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKDistributedLogManager.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKDistributedLogManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKDistributedLogNamespace.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKDistributedLogNamespace.java
index a55d0fc1c8..0a3677d956 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKDistributedLogNamespace.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKDistributedLogNamespace.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogHandler.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogHandler.java
index 75203cc461..4d666509a4 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogHandler.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogHandler.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogReadHandler.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogReadHandler.java
index d7606e2fef..777e6b1c76 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogReadHandler.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogReadHandler.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogSegmentWriter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogSegmentWriter.java
index 388df06b71..ca424639e8 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogSegmentWriter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogSegmentWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogWriteHandler.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogWriteHandler.java
index 1038e68cc3..7fa5e39820 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogWriteHandler.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKLogWriteHandler.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKSyncLogReader.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKSyncLogReader.java
index 37bb8c1d78..7be40f4154 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKSyncLogReader.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKSyncLogReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKSyncLogWriter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKSyncLogWriter.java
index 1568dd0e98..dcd38d4246 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKSyncLogWriter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKSyncLogWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKTransmitPacket.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKTransmitPacket.java
index 82aaa22b97..2cbdf1c00f 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKTransmitPacket.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BKTransmitPacket.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BookKeeperClient.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BookKeeperClient.java
index 8c6c25a0f0..537b760efc 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BookKeeperClient.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BookKeeperClient.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BookKeeperClientBuilder.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BookKeeperClientBuilder.java
index c2152a9e97..677a352ffd 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BookKeeperClientBuilder.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/BookKeeperClientBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/DistributedLogConfiguration.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/DistributedLogConfiguration.java
index 3a0138b6a1..f6d84a908b 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/DistributedLogConfiguration.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/DistributedLogConfiguration.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/DistributedLogConstants.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/DistributedLogConstants.java
index cf2149d4b6..59c2e3c75d 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/DistributedLogConstants.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/DistributedLogConstants.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/Entry.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/Entry.java
index 5122b3b96f..2f124eebfb 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/Entry.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/Entry.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EntryBuffer.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EntryBuffer.java
index 68d76ea4da..492da69e21 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EntryBuffer.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EntryBuffer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EntryPosition.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EntryPosition.java
index 218662c285..33792fd532 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EntryPosition.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EntryPosition.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EnvelopedEntry.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EnvelopedEntry.java
index e0ccef949d..e904b06e74 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EnvelopedEntry.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EnvelopedEntry.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EnvelopedEntryReader.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EnvelopedEntryReader.java
index 6db96e246e..a7f6c4f3ae 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EnvelopedEntryReader.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EnvelopedEntryReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EnvelopedEntryWriter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EnvelopedEntryWriter.java
index e6497e9a5b..a81d2d281a 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EnvelopedEntryWriter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/EnvelopedEntryWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/LocalDLMEmulator.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/LocalDLMEmulator.java
index e33f02bce1..b9a6bb5c4a 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/LocalDLMEmulator.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/LocalDLMEmulator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/LogSegmentMetadata.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/LogSegmentMetadata.java
index f61b50a820..7ea416201e 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/LogSegmentMetadata.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/LogSegmentMetadata.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/MaxLogSegmentSequenceNo.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/MaxLogSegmentSequenceNo.java
index 047f44a835..86020e2af8 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/MaxLogSegmentSequenceNo.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/MaxLogSegmentSequenceNo.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/MaxTxId.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/MaxTxId.java
index 2cdfcbb9bf..f7a9102dd1 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/MaxTxId.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/MaxTxId.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ReadAheadEntryReader.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ReadAheadEntryReader.java
index 64058da08a..77d67ec445 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ReadAheadEntryReader.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ReadAheadEntryReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ReadUtils.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ReadUtils.java
index db1174ff47..c909f83a76 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ReadUtils.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ReadUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/WriteLimiter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/WriteLimiter.java
index 1c97bd8a02..e81f62782c 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/WriteLimiter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/WriteLimiter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ZooKeeperClient.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ZooKeeperClient.java
index 1cf7beabee..91af155a46 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ZooKeeperClient.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ZooKeeperClient.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ZooKeeperClientBuilder.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ZooKeeperClientBuilder.java
index 3cc20e2364..755cd82466 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ZooKeeperClientBuilder.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/ZooKeeperClientBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/acl/AccessControlManager.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/acl/AccessControlManager.java
index 3d634f97f4..f32c41e340 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/acl/AccessControlManager.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/acl/AccessControlManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/acl/DefaultAccessControlManager.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/acl/DefaultAccessControlManager.java
index e86cd0c3eb..bf310bfdb3 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/acl/DefaultAccessControlManager.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/acl/DefaultAccessControlManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/acl/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/acl/package-info.java
index 4218bfc9bd..cb3b3a5a69 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/acl/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/acl/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/admin/DistributedLogAdmin.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/admin/DistributedLogAdmin.java
index 4632efa134..77815fcfaa 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/admin/DistributedLogAdmin.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/admin/DistributedLogAdmin.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/admin/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/admin/package-info.java
index 80b7e77dab..f2a9b9d63e 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/admin/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/admin/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/api/subscription/SubscriptionStateStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/api/subscription/SubscriptionStateStore.java
index 3eca2fdb47..44d83c48c9 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/api/subscription/SubscriptionStateStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/api/subscription/SubscriptionStateStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/api/subscription/SubscriptionsStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/api/subscription/SubscriptionsStore.java
index d956567d25..8942529ab8 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/api/subscription/SubscriptionsStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/api/subscription/SubscriptionsStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/auditor/DLAuditor.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/auditor/DLAuditor.java
index dd652ee008..a356cd7db5 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/auditor/DLAuditor.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/auditor/DLAuditor.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/DynamicQuorumConfigProvider.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/DynamicQuorumConfigProvider.java
index ced43631f1..12aed98ad9 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/DynamicQuorumConfigProvider.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/DynamicQuorumConfigProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/ImmutableQuorumConfigProvider.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/ImmutableQuorumConfigProvider.java
index 463cdf9372..bf95084cf5 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/ImmutableQuorumConfigProvider.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/ImmutableQuorumConfigProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocator.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocator.java
index 15db0bfe29..80f1ce0311 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocator.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocatorDelegator.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocatorDelegator.java
index b86d39732f..c5677edc6a 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocatorDelegator.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocatorDelegator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocatorPool.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocatorPool.java
index 048ce9f3d9..83ee1cf71b 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocatorPool.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocatorPool.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocatorUtils.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocatorUtils.java
index 4184b4c258..2e05dd59e4 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocatorUtils.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/LedgerAllocatorUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/QuorumConfig.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/QuorumConfig.java
index 0cfc0ffd13..712024e5c3 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/QuorumConfig.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/QuorumConfig.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/QuorumConfigProvider.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/QuorumConfigProvider.java
index e48cff393a..e28e088eb3 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/QuorumConfigProvider.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/QuorumConfigProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/SimpleLedgerAllocator.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/SimpleLedgerAllocator.java
index 5e55a432a5..da6ee153e3 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/SimpleLedgerAllocator.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/SimpleLedgerAllocator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/package-info.java
index 6173acdc6a..0ae3fcb521 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/bk/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/LogSegmentListener.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/LogSegmentListener.java
index 3701d2abf3..b9d6e6edac 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/LogSegmentListener.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/LogSegmentListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/LogSegmentNamesListener.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/LogSegmentNamesListener.java
index 260925df71..08b22f9218 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/LogSegmentNamesListener.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/LogSegmentNamesListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/NamespaceListener.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/NamespaceListener.java
index 8a7a1bb873..b8db249e76 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/NamespaceListener.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/NamespaceListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/package-info.java
index 24cca9a177..42a3557960 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/callback/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/config/DynamicConfigurationFactory.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/config/DynamicConfigurationFactory.java
index 2512c3b341..7ef062fb60 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/config/DynamicConfigurationFactory.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/config/DynamicConfigurationFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/config/DynamicDistributedLogConfiguration.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/config/DynamicDistributedLogConfiguration.java
index a6f4d8deef..d6427cd4e3 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/config/DynamicDistributedLogConfiguration.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/config/DynamicDistributedLogConfiguration.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/config/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/config/package-info.java
index e107efe078..08fd6fed2c 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/config/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/config/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/exceptions/ZKException.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/exceptions/ZKException.java
index c4bfbb64af..1193cbe9d9 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/exceptions/ZKException.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/exceptions/ZKException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/exceptions/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/exceptions/package-info.java
index eed88d1277..a561d810e5 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/exceptions/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/exceptions/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/AbstractFeatureProvider.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/AbstractFeatureProvider.java
index a6b5bf5dec..3369bde758 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/AbstractFeatureProvider.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/AbstractFeatureProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/ConfigurationFeatureProvider.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/ConfigurationFeatureProvider.java
index ae0c2dcebc..b11d1486dd 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/ConfigurationFeatureProvider.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/ConfigurationFeatureProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/CoreFeatureKeys.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/CoreFeatureKeys.java
index ad0c07e0a3..f8f78f6c01 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/CoreFeatureKeys.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/CoreFeatureKeys.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/DefaultFeatureProvider.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/DefaultFeatureProvider.java
index 6aa3888074..0debcda05f 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/DefaultFeatureProvider.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/DefaultFeatureProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/DynamicConfigurationFeatureProvider.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/DynamicConfigurationFeatureProvider.java
index 0e3544c65c..f95fca0892 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/DynamicConfigurationFeatureProvider.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/DynamicConfigurationFeatureProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/package-info.java
index c3c242d524..417645647a 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/feature/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/function/GetLastTxIdFunction.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/function/GetLastTxIdFunction.java
index 55c2c6906c..dc78acd9b8 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/function/GetLastTxIdFunction.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/function/GetLastTxIdFunction.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/function/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/function/package-info.java
index 16c2d90fa2..6ebf2cb47b 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/function/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/function/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/BKNamespaceDriver.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/BKNamespaceDriver.java
index afb3c33f96..ea17ed7693 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/BKNamespaceDriver.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/BKNamespaceDriver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKLogMetadataStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKLogMetadataStore.java
index 15277e251d..123be5dfac 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKLogMetadataStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKLogMetadataStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKLogSegmentFilters.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKLogSegmentFilters.java
index 4e64161302..ccdd3b252b 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKLogSegmentFilters.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKLogSegmentFilters.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKLogSegmentMetadataStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKLogSegmentMetadataStore.java
index 924e21bf1d..19320aae71 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKLogSegmentMetadataStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKLogSegmentMetadataStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKMetadataAccessor.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKMetadataAccessor.java
index 6c05090237..9003c2ffe5 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKMetadataAccessor.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKMetadataAccessor.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKNamespaceWatcher.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKNamespaceWatcher.java
index 952f1b3231..e26230c27f 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKNamespaceWatcher.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/ZKNamespaceWatcher.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/acl/ZKAccessControl.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/acl/ZKAccessControl.java
index d47380210d..b0827d0151 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/acl/ZKAccessControl.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/acl/ZKAccessControl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/acl/ZKAccessControlManager.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/acl/ZKAccessControlManager.java
index bf11137734..9ca3efc6cf 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/acl/ZKAccessControlManager.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/acl/ZKAccessControlManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/acl/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/acl/package-info.java
index 18f6b4016f..2f647cceaf 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/acl/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/acl/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/federated/FederatedZKLogMetadataStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/federated/FederatedZKLogMetadataStore.java
index 4ed3c5ed46..028d329e40 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/federated/FederatedZKLogMetadataStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/federated/FederatedZKLogMetadataStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/federated/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/federated/package-info.java
index 22de8a7b9e..9374e7943d 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/federated/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/federated/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentAllocator.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentAllocator.java
index 1ab944303d..56fbbb69ce 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentAllocator.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentAllocator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentEntryReader.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentEntryReader.java
index eb68a7d4e5..dc227f336d 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentEntryReader.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentEntryReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentEntryStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentEntryStore.java
index bb3df1884c..170f75b1a3 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentEntryStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentEntryStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentEntryWriter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentEntryWriter.java
index 51e21fda43..a5bb4204fe 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentEntryWriter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentEntryWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentRandomAccessEntryReader.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentRandomAccessEntryReader.java
index 8221ebfaed..61f157d1df 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentRandomAccessEntryReader.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKLogSegmentRandomAccessEntryReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKUtils.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKUtils.java
index e507c32d89..c41bb9c770 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKUtils.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/BKUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/package-info.java
index d3250bdb98..737c08d760 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/logsegment/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/BKDLConfig.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/BKDLConfig.java
index ba13e285c9..ef2277eb52 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/BKDLConfig.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/BKDLConfig.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/ZKLogStreamMetadataStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/ZKLogStreamMetadataStore.java
index b1ed272c41..b2fa3e653f 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/ZKLogStreamMetadataStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/ZKLogStreamMetadataStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/ZkMetadataResolver.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/ZkMetadataResolver.java
index ca1dad3131..7ceeaceab3 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/ZkMetadataResolver.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/ZkMetadataResolver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/package-info.java
index 4e3cffd362..8727f3c750 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/metadata/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/package-info.java
index ecdd19480f..19245ead45 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/subscription/ZKSubscriptionStateStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/subscription/ZKSubscriptionStateStore.java
index 2b486d34e7..ac7d63dfac 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/subscription/ZKSubscriptionStateStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/subscription/ZKSubscriptionStateStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/subscription/ZKSubscriptionsStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/subscription/ZKSubscriptionsStore.java
index eda9af7557..4f15cb7a8a 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/subscription/ZKSubscriptionsStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/subscription/ZKSubscriptionsStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/subscription/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/subscription/package-info.java
index f004b7190c..56e089f996 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/subscription/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/impl/subscription/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/AsyncFailureInjector.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/AsyncFailureInjector.java
index c748d6b5ae..8959e3f559 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/AsyncFailureInjector.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/AsyncFailureInjector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/AsyncRandomFailureInjector.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/AsyncRandomFailureInjector.java
index b054a679c5..3faa807c1b 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/AsyncRandomFailureInjector.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/AsyncRandomFailureInjector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/FailureInjector.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/FailureInjector.java
index c1b8a98e2a..75f2a235c3 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/FailureInjector.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/FailureInjector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/RandomDelayFailureInjector.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/RandomDelayFailureInjector.java
index e11794d1bb..ef64f90aac 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/RandomDelayFailureInjector.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/RandomDelayFailureInjector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/package-info.java
index 0e50f9bf07..7287efb07c 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/injector/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/ChainedRequestLimiter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/ChainedRequestLimiter.java
index 97bacb6cd0..7fb38fe00d 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/ChainedRequestLimiter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/ChainedRequestLimiter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/ComposableRequestLimiter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/ComposableRequestLimiter.java
index e8e6c7d256..1e07e89d83 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/ComposableRequestLimiter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/ComposableRequestLimiter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/GuavaRateLimiter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/GuavaRateLimiter.java
index 953f959824..6c10ffced9 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/GuavaRateLimiter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/GuavaRateLimiter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/RateLimiter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/RateLimiter.java
index 55f6fd0d1c..d6412fe58a 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/RateLimiter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/RateLimiter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/RequestLimiter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/RequestLimiter.java
index e59014b24e..4c421b2ab0 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/RequestLimiter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/RequestLimiter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/package-info.java
index 3c0d4b5f00..cfe4d65b72 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/limiter/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/DistributedLock.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/DistributedLock.java
index 6fe85df9e3..dc06aa0291 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/DistributedLock.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/DistributedLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/DistributedLockContext.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/DistributedLockContext.java
index c3d64d7af4..fb0a59a289 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/DistributedLockContext.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/DistributedLockContext.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/EpochChangedException.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/EpochChangedException.java
index 2d989e243e..1c2e608915 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/EpochChangedException.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/EpochChangedException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockAction.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockAction.java
index 11d8e83a40..78778d54c1 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockAction.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockAction.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockClosedException.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockClosedException.java
index 22115ae7d9..6254095dee 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockClosedException.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockClosedException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockListener.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockListener.java
index 4810cf1598..c3abcf6968 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockListener.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockListener.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockSessionExpiredException.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockSessionExpiredException.java
index b02c92d25d..da240e2811 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockSessionExpiredException.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockSessionExpiredException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockStateChangedException.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockStateChangedException.java
index 71d26ed8cd..f4ae2db80c 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockStateChangedException.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockStateChangedException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockTimeoutException.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockTimeoutException.java
index 56336f4c80..df3280ad12 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockTimeoutException.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockTimeoutException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockWaiter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockWaiter.java
index b0d1f7fd45..285197c3cb 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockWaiter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/LockWaiter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/NopDistributedLock.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/NopDistributedLock.java
index c8668e76fc..c0c74cd85e 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/NopDistributedLock.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/NopDistributedLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/SessionLock.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/SessionLock.java
index 9abfac9d52..52a0fe31c7 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/SessionLock.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/SessionLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/SessionLockFactory.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/SessionLockFactory.java
index 05c1f8f37a..f427a151b7 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/SessionLockFactory.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/SessionLockFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/ZKDistributedLock.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/ZKDistributedLock.java
index 107c5e3174..4d4c499eeb 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/ZKDistributedLock.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/ZKDistributedLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/ZKSessionLock.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/ZKSessionLock.java
index a1e67f93a1..7d7a292681 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/ZKSessionLock.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/ZKSessionLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/ZKSessionLockFactory.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/ZKSessionLockFactory.java
index 77e35b9c25..ae9e5492a0 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/ZKSessionLockFactory.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/ZKSessionLockFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/package-info.java
index e5c15ab411..8db429d15c 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/lock/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentEntryReader.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentEntryReader.java
index eef5882e1a..decae9a850 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentEntryReader.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentEntryReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentEntryStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentEntryStore.java
index f57a4b5f23..75cca8f307 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentEntryStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentEntryStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentEntryWriter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentEntryWriter.java
index d10091b8da..df00dba7ed 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentEntryWriter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentEntryWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentFilter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentFilter.java
index ffbfb14e77..8fee502e6b 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentFilter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentFilter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentMetadataCache.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentMetadataCache.java
index 4d9958794b..a6da02c3ac 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentMetadataCache.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentMetadataCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentMetadataStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentMetadataStore.java
index 8597d848d4..f7cb516ed1 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentMetadataStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentMetadataStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentRandomAccessEntryReader.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentRandomAccessEntryReader.java
index 23c784e7fe..c8cf16024f 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentRandomAccessEntryReader.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentRandomAccessEntryReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentWriter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentWriter.java
index 6deb205f34..c084b6a32f 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentWriter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/LogSegmentWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/PerStreamLogSegmentCache.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/PerStreamLogSegmentCache.java
index cd9accec4b..59913f2209 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/PerStreamLogSegmentCache.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/PerStreamLogSegmentCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/RollingPolicy.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/RollingPolicy.java
index cf7c266976..a79f1d88df 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/RollingPolicy.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/RollingPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/SizeBasedRollingPolicy.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/SizeBasedRollingPolicy.java
index 17ddb1684e..c8e32abdd3 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/SizeBasedRollingPolicy.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/SizeBasedRollingPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/TimeBasedRollingPolicy.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/TimeBasedRollingPolicy.java
index dbc8daae8d..e8e1647e11 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/TimeBasedRollingPolicy.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/TimeBasedRollingPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/package-info.java
index a79e40a22c..b9b2062fe2 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/logsegment/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/DLConfig.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/DLConfig.java
index 948c3af85e..7c59d95a31 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/DLConfig.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/DLConfig.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/DLMetadata.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/DLMetadata.java
index dcd05ff3b0..81df6f280d 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/DLMetadata.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/DLMetadata.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/DryrunLogSegmentMetadataStoreUpdater.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/DryrunLogSegmentMetadataStoreUpdater.java
index 9b57e11dfd..c96327727f 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/DryrunLogSegmentMetadataStoreUpdater.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/DryrunLogSegmentMetadataStoreUpdater.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadata.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadata.java
index c9f1beb8c0..49a407bcf2 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadata.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadata.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadataForReader.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadataForReader.java
index 9f037f6bbf..2148d623bb 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadataForReader.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadataForReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadataForWriter.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadataForWriter.java
index e63983cc07..feed91e06c 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadataForWriter.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadataForWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadataStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadataStore.java
index c09ceebe3e..8b5130d3cc 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadataStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogMetadataStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogSegmentMetadataStoreUpdater.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogSegmentMetadataStoreUpdater.java
index 205de3afc6..92060e63e3 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogSegmentMetadataStoreUpdater.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogSegmentMetadataStoreUpdater.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogStreamMetadataStore.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogStreamMetadataStore.java
index 3b184d705f..9bb504feb4 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogStreamMetadataStore.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/LogStreamMetadataStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/MetadataResolver.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/MetadataResolver.java
index 09c4a5e36c..f8250e2ba6 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/MetadataResolver.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/MetadataResolver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/MetadataUpdater.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/MetadataUpdater.java
index 0a036c61fb..55874781d6 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/MetadataUpdater.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/MetadataUpdater.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/package-info.java
index a076cd42f8..96019d9784 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/metadata/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/NamespaceDriver.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/NamespaceDriver.java
index 9c61be391f..75908b457a 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/NamespaceDriver.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/NamespaceDriver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/NamespaceDriverManager.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/NamespaceDriverManager.java
index 9446cd6b1d..30155479fb 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/NamespaceDriverManager.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/NamespaceDriverManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/NamespaceWatcher.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/NamespaceWatcher.java
index 703f9cc3b0..49da3d4f75 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/NamespaceWatcher.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/NamespaceWatcher.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/package-info.java
index ddd79c6c81..c7c49f6998 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/namespace/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/DNSResolver.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/DNSResolver.java
index 3ce4fa4697..e6dd55b81f 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/DNSResolver.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/DNSResolver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/DNSResolverForRacks.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/DNSResolverForRacks.java
index 27a3631432..6167cc63c7 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/DNSResolverForRacks.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/DNSResolverForRacks.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/DNSResolverForRows.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/DNSResolverForRows.java
index f2a6be85c6..1b5f5dc03f 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/DNSResolverForRows.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/DNSResolverForRows.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/NetUtils.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/NetUtils.java
index 13f0fe6e7d..27b693d106 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/NetUtils.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/NetUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/package-info.java
index 70b188243f..393755b9b1 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/net/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/package-info.java
index 984acfaeb5..b8a50dd330 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/FirstDLSNNotLessThanSelector.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/FirstDLSNNotLessThanSelector.java
index 1bba6278e1..9120ef5984 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/FirstDLSNNotLessThanSelector.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/FirstDLSNNotLessThanSelector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/FirstRecordSelector.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/FirstRecordSelector.java
index 3247a6c32b..2facee9f74 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/FirstRecordSelector.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/FirstRecordSelector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/FirstTxIdNotLessThanSelector.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/FirstTxIdNotLessThanSelector.java
index cd4e5a2542..866a3a9a2c 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/FirstTxIdNotLessThanSelector.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/FirstTxIdNotLessThanSelector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/LastRecordSelector.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/LastRecordSelector.java
index adabe41d34..854e9dd7f6 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/LastRecordSelector.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/LastRecordSelector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/LogRecordSelector.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/LogRecordSelector.java
index c32ddc9b16..5287f5e55b 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/LogRecordSelector.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/LogRecordSelector.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/package-info.java
index be9ad7f58b..f3f4be688c 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/selector/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/thrift/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/thrift/package-info.java
index ffe2303a0c..1e71f9459f 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/thrift/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/thrift/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/tools/DistributedLogTool.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/tools/DistributedLogTool.java
index d4e782fbd5..c891ecac0d 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/tools/DistributedLogTool.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/tools/DistributedLogTool.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/tools/Tool.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/tools/Tool.java
index 77a6406efb..9243438936 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/tools/Tool.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/tools/Tool.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/tools/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/tools/package-info.java
index 0b79fc7586..f809f532b2 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/tools/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/tools/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/Allocator.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/Allocator.java
index 91403ffe81..3c2a7e243c 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/Allocator.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/Allocator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/CommandLineUtils.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/CommandLineUtils.java
index d0af2770c4..2796c79f60 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/CommandLineUtils.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/CommandLineUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/ConfUtils.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/ConfUtils.java
index 8c51f9ee62..0017c3e985 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/ConfUtils.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/ConfUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/DLUtils.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/DLUtils.java
index 6c579c2957..6ee3ba7d88 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/DLUtils.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/DLUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/FailpointUtils.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/FailpointUtils.java
index 0d3be1b214..28e83efc71 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/FailpointUtils.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/FailpointUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/RetryPolicyUtils.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/RetryPolicyUtils.java
index 0473ef31c6..eb02fa9085 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/RetryPolicyUtils.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/RetryPolicyUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/TimeSequencer.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/TimeSequencer.java
index 5bc5af20ec..98b70b2bb7 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/TimeSequencer.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/TimeSequencer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/Utils.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/Utils.java
index e7cd70b425..36b8346734 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/Utils.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/Utils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/package-info.java
index 4a99666a5a..93899c954b 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/util/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/DefaultZKOp.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/DefaultZKOp.java
index 4ade77f4db..22ae7cb9fd 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/DefaultZKOp.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/DefaultZKOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/LimitedPermitManager.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/LimitedPermitManager.java
index 211d10c3fc..205fd18985 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/LimitedPermitManager.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/LimitedPermitManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKOp.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKOp.java
index 715c5ece8e..c37156c94e 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKOp.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKTransaction.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKTransaction.java
index a6024e20ce..172c390f28 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKTransaction.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKTransaction.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKVersionedSetOp.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKVersionedSetOp.java
index 64224ad4b2..ac33119a2c 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKVersionedSetOp.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKVersionedSetOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKWatcherManager.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKWatcherManager.java
index cbdae1d735..1aabd59636 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKWatcherManager.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/ZKWatcherManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/package-info.java b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/package-info.java
index 98f238b726..27452a96ca 100644
--- a/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/package-info.java
+++ b/stream/distributedlog/core/src/main/java/org/apache/distributedlog/zk/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/main/thrift/metadata.thrift b/stream/distributedlog/core/src/main/thrift/metadata.thrift
index 4c9918bb29..1bf1b4c859 100644
--- a/stream/distributedlog/core/src/main/thrift/metadata.thrift
+++ b/stream/distributedlog/core/src/main/thrift/metadata.thrift
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/DLMTestUtil.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/DLMTestUtil.java
index 1e5adf3f5b..ec27b19bb0 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/DLMTestUtil.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/DLMTestUtil.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/NonBlockingReadsTestUtil.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/NonBlockingReadsTestUtil.java
index 47973b9f2c..7100452797 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/NonBlockingReadsTestUtil.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/NonBlockingReadsTestUtil.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAppendOnlyStreamReader.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAppendOnlyStreamReader.java
index e8f897ce5c..e118e289ea 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAppendOnlyStreamReader.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAppendOnlyStreamReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAppendOnlyStreamWriter.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAppendOnlyStreamWriter.java
index f9acd7c003..0608bd6bc4 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAppendOnlyStreamWriter.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAppendOnlyStreamWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAsyncBulkWrite.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAsyncBulkWrite.java
index c6a4fdfab0..71a945ec65 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAsyncBulkWrite.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAsyncBulkWrite.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAsyncReaderLock.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAsyncReaderLock.java
index 72a3ced443..a4ceea79af 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAsyncReaderLock.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAsyncReaderLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAsyncReaderWriter.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAsyncReaderWriter.java
index 9d6af76d25..70c9b0dc32 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAsyncReaderWriter.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestAsyncReaderWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKDistributedLogManager.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKDistributedLogManager.java
index 0245b40e71..e26667dd04 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKDistributedLogManager.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKDistributedLogManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKDistributedLogNamespace.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKDistributedLogNamespace.java
index b20d51ea13..d0372612fd 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKDistributedLogNamespace.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKDistributedLogNamespace.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKLogReadHandler.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKLogReadHandler.java
index da4dabd71c..323a0f59fe 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKLogReadHandler.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKLogReadHandler.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKLogSegmentWriter.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKLogSegmentWriter.java
index 7eea32d0a4..89aab53e07 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKLogSegmentWriter.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKLogSegmentWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKLogWriteHandler.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKLogWriteHandler.java
index 3a3171cb95..f4a3050ec7 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKLogWriteHandler.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKLogWriteHandler.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKSyncLogReader.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKSyncLogReader.java
index ec99e7acf4..fc1f70b966 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKSyncLogReader.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestBKSyncLogReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestCancelledRead.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestCancelledRead.java
index 40cf632688..ae306b87cc 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestCancelledRead.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestCancelledRead.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestDLMTestUtil.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestDLMTestUtil.java
index 3f1602d167..73d7d9df7c 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestDLMTestUtil.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestDLMTestUtil.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestDistributedLogBase.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestDistributedLogBase.java
index dde80bc918..cbd135de89 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestDistributedLogBase.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestDistributedLogBase.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestDistributedLogConfiguration.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestDistributedLogConfiguration.java
index 03a7a209d0..4fbe4f5f7d 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestDistributedLogConfiguration.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestDistributedLogConfiguration.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestEntry.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestEntry.java
index 3b0a9de9a6..eb225809eb 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestEntry.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestEntry.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestEntryPosition.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestEntryPosition.java
index 01a784ddad..d4319804ae 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestEntryPosition.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestEntryPosition.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestInterleavedReaders.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestInterleavedReaders.java
index 7a80fd5067..059b06511f 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestInterleavedReaders.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestInterleavedReaders.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestLogSegmentCreation.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestLogSegmentCreation.java
index 90565c9b1b..506e253914 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestLogSegmentCreation.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestLogSegmentCreation.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestLogSegmentMetadata.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestLogSegmentMetadata.java
index 6fbdeaac58..87b2b92b64 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestLogSegmentMetadata.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestLogSegmentMetadata.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestLogSegmentsZK.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestLogSegmentsZK.java
index 61cf16c166..5e1688f7c6 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestLogSegmentsZK.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestLogSegmentsZK.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestNonBlockingReads.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestNonBlockingReads.java
index ef9f184503..8c89792445 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestNonBlockingReads.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestNonBlockingReads.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestNonBlockingReadsMultiReader.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestNonBlockingReadsMultiReader.java
index 98baa4a617..a90301d53e 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestNonBlockingReadsMultiReader.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestNonBlockingReadsMultiReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestReadAheadEntryReader.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestReadAheadEntryReader.java
index 7cc34534c2..6cb1e5d5f5 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestReadAheadEntryReader.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestReadAheadEntryReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestReadUtils.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestReadUtils.java
index 9adf6f6eed..3fbcd700cf 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestReadUtils.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestReadUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestReader.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestReader.java
index ed432873e7..de880ee3d0 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestReader.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestRollLogSegments.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestRollLogSegments.java
index 7b992da8d4..180646ac70 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestRollLogSegments.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestRollLogSegments.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestSequenceID.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestSequenceID.java
index 19605203c1..377629e0eb 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestSequenceID.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestSequenceID.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestTruncate.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestTruncate.java
index 5c779aca3a..e32b5f2f7a 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestTruncate.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestTruncate.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestTxnId.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestTxnId.java
index 07c6c1aa0b..2eb6a61683 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestTxnId.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestTxnId.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestWriteLimiter.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestWriteLimiter.java
index d009991bf0..898bc86fe2 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestWriteLimiter.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestWriteLimiter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestZooKeeperClient.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestZooKeeperClient.java
index a5888619f0..a9ff1d1cbe 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestZooKeeperClient.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestZooKeeperClient.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestZooKeeperClientBuilder.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestZooKeeperClientBuilder.java
index 6f6f348168..bc41d7f6f4 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestZooKeeperClientBuilder.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/TestZooKeeperClientBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/ZooKeeperClientUtils.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/ZooKeeperClientUtils.java
index a286ae50ae..3e52d979f1 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/ZooKeeperClientUtils.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/ZooKeeperClientUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/ZooKeeperClusterTestCase.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/ZooKeeperClusterTestCase.java
index 7fb8bef67b..a3d59ef210 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/ZooKeeperClusterTestCase.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/ZooKeeperClusterTestCase.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/acl/TestZKAccessControl.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/acl/TestZKAccessControl.java
index 9c0b9409b5..4e7628b746 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/acl/TestZKAccessControl.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/acl/TestZKAccessControl.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/acl/TestZKAccessControlManager.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/acl/TestZKAccessControlManager.java
index b4568c7191..940a18dcda 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/acl/TestZKAccessControlManager.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/acl/TestZKAccessControlManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/admin/TestDLCK.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/admin/TestDLCK.java
index 85efb22619..bed16ad5c0 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/admin/TestDLCK.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/admin/TestDLCK.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/admin/TestDistributedLogAdmin.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/admin/TestDistributedLogAdmin.java
index b48d002d4a..e4c9a77ce0 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/admin/TestDistributedLogAdmin.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/admin/TestDistributedLogAdmin.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/bk/TestLedgerAllocator.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/bk/TestLedgerAllocator.java
index 5819a0d4c4..23d958dfc6 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/bk/TestLedgerAllocator.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/bk/TestLedgerAllocator.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/bk/TestLedgerAllocatorPool.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/bk/TestLedgerAllocatorPool.java
index 3d258b7d29..1528518d08 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/bk/TestLedgerAllocatorPool.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/bk/TestLedgerAllocatorPool.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/config/TestDynamicConfigurationFactory.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/config/TestDynamicConfigurationFactory.java
index 02eea8083c..d8bac3cd49 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/config/TestDynamicConfigurationFactory.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/config/TestDynamicConfigurationFactory.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/config/TestDynamicDistributedLogConfiguration.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/config/TestDynamicDistributedLogConfiguration.java
index eebf06e912..00d4a96f25 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/config/TestDynamicDistributedLogConfiguration.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/config/TestDynamicDistributedLogConfiguration.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/feature/TestConfigurationFeatureProvider.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/feature/TestConfigurationFeatureProvider.java
index a94b5ba83b..a35a5117c1 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/feature/TestConfigurationFeatureProvider.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/feature/TestConfigurationFeatureProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/feature/TestDynamicConfigurationFeatureProvider.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/feature/TestDynamicConfigurationFeatureProvider.java
index e3953450bb..1ebab1e545 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/feature/TestDynamicConfigurationFeatureProvider.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/feature/TestDynamicConfigurationFeatureProvider.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKLogMetadataStore.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKLogMetadataStore.java
index 12ad923d1d..1a4ef238b1 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKLogMetadataStore.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKLogMetadataStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKLogSegmentFilters.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKLogSegmentFilters.java
index 93ed561724..cefee7d783 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKLogSegmentFilters.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKLogSegmentFilters.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKLogSegmentMetadataStore.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKLogSegmentMetadataStore.java
index c26a7f0a0a..f466a781d3 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKLogSegmentMetadataStore.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKLogSegmentMetadataStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKNamespaceWatcher.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKNamespaceWatcher.java
index 29b42bb795..3143e7ff4a 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKNamespaceWatcher.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/TestZKNamespaceWatcher.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/federated/TestFederatedZKLogMetadataStore.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/federated/TestFederatedZKLogMetadataStore.java
index 3ce838dff8..d4282baf6e 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/federated/TestFederatedZKLogMetadataStore.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/federated/TestFederatedZKLogMetadataStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/logsegment/TestBKLogSegmentEntryReader.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/logsegment/TestBKLogSegmentEntryReader.java
index a05dd6e2bc..dd37b3cef5 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/logsegment/TestBKLogSegmentEntryReader.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/logsegment/TestBKLogSegmentEntryReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/metadata/TestZKLogStreamMetadataStore.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/metadata/TestZKLogStreamMetadataStore.java
index dde450dd50..d4a6764a02 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/metadata/TestZKLogStreamMetadataStore.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/metadata/TestZKLogStreamMetadataStore.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/metadata/TestZKLogStreamMetadataStoreUtils.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/metadata/TestZKLogStreamMetadataStoreUtils.java
index 58c0de6009..cc53775572 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/metadata/TestZKLogStreamMetadataStoreUtils.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/metadata/TestZKLogStreamMetadataStoreUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/metadata/TestZkMetadataResolver.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/metadata/TestZkMetadataResolver.java
index 38f9c0b490..944ce98815 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/metadata/TestZkMetadataResolver.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/impl/metadata/TestZkMetadataResolver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/limiter/TestRequestLimiter.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/limiter/TestRequestLimiter.java
index c9ad2a153a..07eae94a4d 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/limiter/TestRequestLimiter.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/limiter/TestRequestLimiter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/lock/TestDistributedLock.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/lock/TestDistributedLock.java
index 89c3817c74..43e9aca052 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/lock/TestDistributedLock.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/lock/TestDistributedLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/lock/TestZKSessionLock.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/lock/TestZKSessionLock.java
index 8a9d9c2f82..9c05f6ef47 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/lock/TestZKSessionLock.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/lock/TestZKSessionLock.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/logsegment/TestPerStreamLogSegmentCache.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/logsegment/TestPerStreamLogSegmentCache.java
index b9ae8f0292..c31073bb8d 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/logsegment/TestPerStreamLogSegmentCache.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/logsegment/TestPerStreamLogSegmentCache.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/logsegment/TestRollingPolicy.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/logsegment/TestRollingPolicy.java
index 7a4deb6aa3..246d4f83d5 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/logsegment/TestRollingPolicy.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/logsegment/TestRollingPolicy.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/metadata/TestDLMetadata.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/metadata/TestDLMetadata.java
index 093a561388..9f0d86a20d 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/metadata/TestDLMetadata.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/metadata/TestDLMetadata.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/metadata/TestLogMetadata.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/metadata/TestLogMetadata.java
index e3daed8e6a..ade3159438 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/metadata/TestLogMetadata.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/metadata/TestLogMetadata.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/metadata/TestLogSegmentMetadataStoreUpdater.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/metadata/TestLogSegmentMetadataStoreUpdater.java
index c21068fb20..a7b6f7fa98 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/metadata/TestLogSegmentMetadataStoreUpdater.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/metadata/TestLogSegmentMetadataStoreUpdater.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/namespace/TestNamespaceBuilder.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/namespace/TestNamespaceBuilder.java
index b905c41af0..e7141c4540 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/namespace/TestNamespaceBuilder.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/namespace/TestNamespaceBuilder.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/net/TestDNSResolver.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/net/TestDNSResolver.java
index a804d9a0ce..c1f4ec27e9 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/net/TestDNSResolver.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/net/TestDNSResolver.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/net/TestNetUtils.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/net/TestNetUtils.java
index 7cfc76f632..30c3116845 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/net/TestNetUtils.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/net/TestNetUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/selector/TestLogRecordSelectors.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/selector/TestLogRecordSelectors.java
index 46b4c70f6f..ee4f56fa7c 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/selector/TestLogRecordSelectors.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/selector/TestLogRecordSelectors.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/tools/TestDistributedLogTool.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/tools/TestDistributedLogTool.java
index d98ceade60..4aa6ac1576 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/tools/TestDistributedLogTool.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/tools/TestDistributedLogTool.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestConfUtils.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestConfUtils.java
index 36c22c4fd4..366d561eb6 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestConfUtils.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestConfUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestDLUtils.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestDLUtils.java
index 2952683273..855935ce75 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestDLUtils.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestDLUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestPermitManager.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestPermitManager.java
index f47d0d9ece..f36c30c335 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestPermitManager.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestPermitManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestTimeSequencer.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestTimeSequencer.java
index 7230fa89f4..5efd9997ca 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestTimeSequencer.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestTimeSequencer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestUtils.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestUtils.java
index 039c71c281..6ae197acb5 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestUtils.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/util/TestUtils.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/zk/TestZKTransaction.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/zk/TestZKTransaction.java
index e95aefc866..0ec9d40e19 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/zk/TestZKTransaction.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/zk/TestZKTransaction.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/zk/TestZKVersionedSetOp.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/zk/TestZKVersionedSetOp.java
index fab56ea4f4..52779387df 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/zk/TestZKVersionedSetOp.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/zk/TestZKVersionedSetOp.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/zk/TestZKWatcherManager.java b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/zk/TestZKWatcherManager.java
index 3b5908f1b4..64c2ac1556 100644
--- a/stream/distributedlog/core/src/test/java/org/apache/distributedlog/zk/TestZKWatcherManager.java
+++ b/stream/distributedlog/core/src/test/java/org/apache/distributedlog/zk/TestZKWatcherManager.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/DLSN.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/DLSN.java
index 11699da0ea..5941bc4b12 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/DLSN.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/DLSN.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/EnvelopedRecordSetReader.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/EnvelopedRecordSetReader.java
index fd2bbd4905..30c0f910f4 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/EnvelopedRecordSetReader.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/EnvelopedRecordSetReader.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/EnvelopedRecordSetWriter.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/EnvelopedRecordSetWriter.java
index 78d19c3989..0c4b2fb475 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/EnvelopedRecordSetWriter.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/EnvelopedRecordSetWriter.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecord.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecord.java
index 157ce184ce..56fc17f76b 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecord.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecord.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecordSet.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecordSet.java
index 8db601942f..7c04253a64 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecordSet.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecordSet.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecordSetBuffer.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecordSetBuffer.java
index 27d54f8a15..7218fa86a1 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecordSetBuffer.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecordSetBuffer.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecordWithDLSN.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecordWithDLSN.java
index ac9c3a8608..0d709b5602 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecordWithDLSN.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/LogRecordWithDLSN.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/RecordStream.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/RecordStream.java
index 253f1f2e96..09c34d17c8 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/RecordStream.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/RecordStream.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/AlreadyClosedException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/AlreadyClosedException.java
index 258ff055be..6a91d2de8b 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/AlreadyClosedException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/AlreadyClosedException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/AlreadyTruncatedTransactionException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/AlreadyTruncatedTransactionException.java
index 29903ac8db..b025f6dd07 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/AlreadyTruncatedTransactionException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/AlreadyTruncatedTransactionException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/BKTransmitException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/BKTransmitException.java
index 33f4a047b1..6ce2f7e298 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/BKTransmitException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/BKTransmitException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/ChecksumFailedException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/ChecksumFailedException.java
index 4210d668ee..46e57f18e5 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/ChecksumFailedException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/ChecksumFailedException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLClientClosedException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLClientClosedException.java
index bb7c2db188..084127f4a8 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLClientClosedException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLClientClosedException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLException.java
index 928895d7ac..8d8b3d4ff6 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLIllegalStateException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLIllegalStateException.java
index 8dc41166d2..6a42933047 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLIllegalStateException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLIllegalStateException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLInterruptedException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLInterruptedException.java
index 7b4d5be71e..06e5dc4757 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLInterruptedException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/DLInterruptedException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/EndOfLogSegmentException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/EndOfLogSegmentException.java
index 5c1299581f..0c943ee423 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/EndOfLogSegmentException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/EndOfLogSegmentException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/EndOfStreamException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/EndOfStreamException.java
index cc2c79f982..c21c6bf770 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/EndOfStreamException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/EndOfStreamException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/FlushException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/FlushException.java
index b4717786c2..475f8cbcd3 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/FlushException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/FlushException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/IdleReaderException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/IdleReaderException.java
index 048a763b47..248d331d11 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/IdleReaderException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/IdleReaderException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/InternalServerException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/InternalServerException.java
index ff6338ab98..4a8dc534a1 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/InternalServerException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/InternalServerException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/InvalidEnvelopedEntryException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/InvalidEnvelopedEntryException.java
index b52af61fe3..4e761fb956 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/InvalidEnvelopedEntryException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/InvalidEnvelopedEntryException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/InvalidStreamNameException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/InvalidStreamNameException.java
index ca6f4dba4f..d30811ebd4 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/InvalidStreamNameException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/InvalidStreamNameException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LockCancelledException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LockCancelledException.java
index 7f66232872..5bee38a718 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LockCancelledException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LockCancelledException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LockingException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LockingException.java
index 55bd88f151..93d8ed1c45 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LockingException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LockingException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogEmptyException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogEmptyException.java
index 0326a9ad3c..deb1ce9ce5 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogEmptyException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogEmptyException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogExistsException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogExistsException.java
index cb2bc6529b..2ba2892c8d 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogExistsException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogExistsException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogNotFoundException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogNotFoundException.java
index 9ac14ba80a..a926cf68fa 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogNotFoundException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogNotFoundException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogReadException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogReadException.java
index d2ca399b3e..4b6e27a19c 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogReadException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogReadException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogRecordTooLongException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogRecordTooLongException.java
index dd1d66d4b5..a051bb11bc 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogRecordTooLongException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogRecordTooLongException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogSegmentIsTruncatedException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogSegmentIsTruncatedException.java
index 3364940d48..4fe8a2a936 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogSegmentIsTruncatedException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogSegmentIsTruncatedException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogSegmentNotFoundException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogSegmentNotFoundException.java
index 7fad552dbc..3e1445d123 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogSegmentNotFoundException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/LogSegmentNotFoundException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/MetadataException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/MetadataException.java
index 559972b600..4204a896c1 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/MetadataException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/MetadataException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/NotYetImplementedException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/NotYetImplementedException.java
index 75eaa52525..260bfa523a 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/NotYetImplementedException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/NotYetImplementedException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/OverCapacityException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/OverCapacityException.java
index 4247874bc8..f087040ca5 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/OverCapacityException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/OverCapacityException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/OwnershipAcquireFailedException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/OwnershipAcquireFailedException.java
index b077f5e6a5..0bff439b2d 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/OwnershipAcquireFailedException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/OwnershipAcquireFailedException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/ReadCancelledException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/ReadCancelledException.java
index b179ce6324..6251c45dea 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/ReadCancelledException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/ReadCancelledException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/RegionUnavailableException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/RegionUnavailableException.java
index 745ae6b869..2e0da71449 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/RegionUnavailableException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/RegionUnavailableException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/RequestDeniedException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/RequestDeniedException.java
index e26f6db1ef..c4a74af5b1 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/RequestDeniedException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/RequestDeniedException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/RetryableReadException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/RetryableReadException.java
index 1ed506fd5b..f4167a9f42 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/RetryableReadException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/RetryableReadException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/ServiceUnavailableException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/ServiceUnavailableException.java
index 5ab7f03c35..e4f13a39fd 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/ServiceUnavailableException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/ServiceUnavailableException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/StatusCode.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/StatusCode.java
index 6dbb931b3c..53b42b2eed 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/StatusCode.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/StatusCode.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/StreamNotReadyException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/StreamNotReadyException.java
index a58a80fbbd..b82a0ef4d8 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/StreamNotReadyException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/StreamNotReadyException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/StreamUnavailableException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/StreamUnavailableException.java
index ecba754249..bba5cad73d 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/StreamUnavailableException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/StreamUnavailableException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/TooManyStreamsException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/TooManyStreamsException.java
index cc948d9e55..dbbc119e19 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/TooManyStreamsException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/TooManyStreamsException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/TransactionIdOutOfOrderException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/TransactionIdOutOfOrderException.java
index 50c151fabe..b26acdd53c 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/TransactionIdOutOfOrderException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/TransactionIdOutOfOrderException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/UnexpectedException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/UnexpectedException.java
index 50c21aa4f4..5c31e5bac5 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/UnexpectedException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/UnexpectedException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/UnsupportedMetadataVersionException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/UnsupportedMetadataVersionException.java
index 7eb6ed5be9..2caa6afae8 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/UnsupportedMetadataVersionException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/UnsupportedMetadataVersionException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/WriteCancelledException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/WriteCancelledException.java
index 8db1d505ba..dfc813c073 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/WriteCancelledException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/WriteCancelledException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/WriteException.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/WriteException.java
index 549fd41e64..873ce7597a 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/WriteException.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/WriteException.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/package-info.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/package-info.java
index 1ac2bca8f2..8a101cd12b 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/package-info.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/exceptions/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/package-info.java b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/package-info.java
index 41ddd82355..251690f85a 100644
--- a/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/package-info.java
+++ b/stream/distributedlog/protocol/src/main/java/org/apache/distributedlog/package-info.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/test/java/org/apache/distributedlog/TestDLSN.java b/stream/distributedlog/protocol/src/test/java/org/apache/distributedlog/TestDLSN.java
index f18f67c7aa..fc3c58a041 100644
--- a/stream/distributedlog/protocol/src/test/java/org/apache/distributedlog/TestDLSN.java
+++ b/stream/distributedlog/protocol/src/test/java/org/apache/distributedlog/TestDLSN.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/distributedlog/protocol/src/test/java/org/apache/distributedlog/TestLogRecordSet.java b/stream/distributedlog/protocol/src/test/java/org/apache/distributedlog/TestLogRecordSet.java
index 6aa98a90e0..a85920e68a 100644
--- a/stream/distributedlog/protocol/src/test/java/org/apache/distributedlog/TestLogRecordSet.java
+++ b/stream/distributedlog/protocol/src/test/java/org/apache/distributedlog/TestLogRecordSet.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/proto/src/main/proto/cluster.proto b/stream/proto/src/main/proto/cluster.proto
index 20e9d6ddb6..d66eb1831a 100644
--- a/stream/proto/src/main/proto/cluster.proto
+++ b/stream/proto/src/main/proto/cluster.proto
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/proto/src/main/proto/common.proto b/stream/proto/src/main/proto/common.proto
index 1120770a71..c0957f0d2a 100644
--- a/stream/proto/src/main/proto/common.proto
+++ b/stream/proto/src/main/proto/common.proto
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/proto/src/main/proto/kv.proto b/stream/proto/src/main/proto/kv.proto
index ff3b505389..e2a4827dca 100644
--- a/stream/proto/src/main/proto/kv.proto
+++ b/stream/proto/src/main/proto/kv.proto
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/proto/src/main/proto/kv_rpc.proto b/stream/proto/src/main/proto/kv_rpc.proto
index 01e5cb6a5d..13cd7dbc74 100644
--- a/stream/proto/src/main/proto/kv_rpc.proto
+++ b/stream/proto/src/main/proto/kv_rpc.proto
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/proto/src/main/proto/kv_store.proto b/stream/proto/src/main/proto/kv_store.proto
index b198de9a2f..f4cb16f6f1 100644
--- a/stream/proto/src/main/proto/kv_store.proto
+++ b/stream/proto/src/main/proto/kv_store.proto
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/proto/src/main/proto/storage.proto b/stream/proto/src/main/proto/storage.proto
index 664809097e..f7e8465526 100644
--- a/stream/proto/src/main/proto/storage.proto
+++ b/stream/proto/src/main/proto/storage.proto
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/proto/src/main/proto/stream.proto b/stream/proto/src/main/proto/stream.proto
index fd4d4cdba2..b16bd22f29 100644
--- a/stream/proto/src/main/proto/stream.proto
+++ b/stream/proto/src/main/proto/stream.proto
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/statelib/src/main/java/org/apache/bookkeeper/statelib/impl/Bytes.java b/stream/statelib/src/main/java/org/apache/bookkeeper/statelib/impl/Bytes.java
index a774bd3b6d..0cee92b8f3 100644
--- a/stream/statelib/src/main/java/org/apache/bookkeeper/statelib/impl/Bytes.java
+++ b/stream/statelib/src/main/java/org/apache/bookkeeper/statelib/impl/Bytes.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/statelib/src/main/proto/kv.proto b/stream/statelib/src/main/proto/kv.proto
index b54b3e4b96..8ec39e0962 100644
--- a/stream/statelib/src/main/proto/kv.proto
+++ b/stream/statelib/src/main/proto/kv.proto
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/stream/tests-common/src/main/proto/rpc.proto b/stream/tests-common/src/main/proto/rpc.proto
index 8bda3690eb..2766eb5bf9 100644
--- a/stream/tests-common/src/main/proto/rpc.proto
+++ b/stream/tests-common/src/main/proto/rpc.proto
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information
diff --git a/tests/backward-compat/bc-non-fips/src/test/java/org/apache/bookkeeper/tls/TestBCNonFips.java b/tests/backward-compat/bc-non-fips/src/test/java/org/apache/bookkeeper/tls/TestBCNonFips.java
index eded70b0a5..7fd2e7f75e 100644
--- a/tests/backward-compat/bc-non-fips/src/test/java/org/apache/bookkeeper/tls/TestBCNonFips.java
+++ b/tests/backward-compat/bc-non-fips/src/test/java/org/apache/bookkeeper/tls/TestBCNonFips.java
@@ -1,4 +1,4 @@
-/**
+/*
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information